POST CREATE_Attachment_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
BODY json

{}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{}");

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

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment" {:headers {:user-agent ""
                                                                                                                   :x-bunq-client-authentication ""}
                                                                                                         :content-type :json})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment"

	payload := strings.NewReader("{}")

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

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

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

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

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

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/attachment HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 2

{}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{}")
  .asString();
const data = JSON.stringify({});

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

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

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

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

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

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

req.write(JSON.stringify({}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {},
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {}
};

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

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{}'
};

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

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{  };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

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

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment', [
  'body' => '{}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

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

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment' -Method POST -Headers $headers -ContentType 'application/json' -Body '{}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment' -Method POST -Headers $headers -ContentType 'application/json' -Body '{}'
import http.client

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

payload = "{}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/attachment", payload, headers)

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

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

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment"

payload = {}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment"

payload <- "{}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment")

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

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{}"

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

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

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/attachment') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{}"
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment";

    let payload = json!({});

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{}'
echo '{}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

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

dataTask.resume()
GET READ_Attachment_for_User
{{baseUrl}}/user/:userID/attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/user/:userID/attachment/:itemId" {:headers {:user-agent ""
                                                                                     :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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

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

func main() {

	url := "{{baseUrl}}/user/:userID/attachment/:itemId"

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

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

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

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

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

}
GET /baseUrl/user/:userID/attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/attachment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/user/:userID/attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/attachment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/attachment/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/attachment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

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

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

const req = unirest('GET', '{{baseUrl}}/user/:userID/attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

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

const url = '{{baseUrl}}/user/:userID/attachment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

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

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/attachment/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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

let uri = Uri.of_string "{{baseUrl}}/user/:userID/attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/attachment/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

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

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/attachment/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/attachment/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/attachment/:itemId' -Method GET -Headers $headers
import http.client

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

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/attachment/:itemId", headers=headers)

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

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

url = "{{baseUrl}}/user/:userID/attachment/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

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

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

url <- "{{baseUrl}}/user/:userID/attachment/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/user/:userID/attachment/:itemId")

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

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

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

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

response = conn.get('/baseUrl/user/:userID/attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

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

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/attachment/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/attachment/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

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

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

dataTask.resume()
POST CREATE_AttachmentPublic
{{baseUrl}}/attachment-public
HEADERS

User-Agent
X-Bunq-Client-Authentication
BODY json

{}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/attachment-public");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{}");

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

(client/post "{{baseUrl}}/attachment-public" {:headers {:user-agent ""
                                                                        :x-bunq-client-authentication ""}
                                                              :content-type :json})
require "http/client"

url = "{{baseUrl}}/attachment-public"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{}"

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

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

func main() {

	url := "{{baseUrl}}/attachment-public"

	payload := strings.NewReader("{}")

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

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

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

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

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

}
POST /baseUrl/attachment-public HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 2

{}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/attachment-public")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/attachment-public"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/attachment-public")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/attachment-public")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{}")
  .asString();
const data = JSON.stringify({});

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

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

xhr.open('POST', '{{baseUrl}}/attachment-public');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/attachment-public',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/attachment-public';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/attachment-public',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{}")
val request = Request.Builder()
  .url("{{baseUrl}}/attachment-public")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/attachment-public',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

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

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

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

req.write(JSON.stringify({}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/attachment-public',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {},
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/attachment-public');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/attachment-public',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {}
};

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

const url = '{{baseUrl}}/attachment-public';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{}'
};

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

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{  };

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

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

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

let uri = Uri.of_string "{{baseUrl}}/attachment-public" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/attachment-public",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/attachment-public', [
  'body' => '{}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

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

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

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

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  
]));
$request->setRequestUrl('{{baseUrl}}/attachment-public');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/attachment-public' -Method POST -Headers $headers -ContentType 'application/json' -Body '{}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/attachment-public' -Method POST -Headers $headers -ContentType 'application/json' -Body '{}'
import http.client

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

payload = "{}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/attachment-public", payload, headers)

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

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

url = "{{baseUrl}}/attachment-public"

payload = {}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/attachment-public"

payload <- "{}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/attachment-public")

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

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{}"

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

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

response = conn.post('/baseUrl/attachment-public') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{}"
end

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

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

    let payload = json!({});

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/attachment-public \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{}'
echo '{}' |  \
  http POST {{baseUrl}}/attachment-public \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{}' \
  --output-document \
  - {{baseUrl}}/attachment-public
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [] as [String : Any]

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

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

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

dataTask.resume()
GET READ_AttachmentPublic
{{baseUrl}}/attachment-public/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/attachment-public/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/attachment-public/:itemId" {:headers {:user-agent ""
                                                                               :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/attachment-public/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/attachment-public/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/attachment-public/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/attachment-public/:itemId"

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

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

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

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

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

}
GET /baseUrl/attachment-public/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/attachment-public/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/attachment-public/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/attachment-public/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/attachment-public/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/attachment-public/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/attachment-public/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/attachment-public/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/attachment-public/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/attachment-public/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/attachment-public/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

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

  res.on('data', function (chunk) {
    chunks.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}}/attachment-public/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

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

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

const req = unirest('GET', '{{baseUrl}}/attachment-public/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/attachment-public/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

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

const url = '{{baseUrl}}/attachment-public/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

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

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/attachment-public/:itemId"]
                                                       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}}/attachment-public/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/attachment-public/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/attachment-public/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/attachment-public/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/attachment-public/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/attachment-public/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/attachment-public/:itemId' -Method GET -Headers $headers
import http.client

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

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/attachment-public/:itemId", headers=headers)

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

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

url = "{{baseUrl}}/attachment-public/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

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

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

url <- "{{baseUrl}}/attachment-public/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/attachment-public/:itemId")

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

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

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

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

response = conn.get('/baseUrl/attachment-public/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

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

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".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}}/attachment-public/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/attachment-public/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/attachment-public/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

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

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

dataTask.resume()
POST CREATE_Avatar
{{baseUrl}}/avatar
HEADERS

User-Agent
X-Bunq-Client-Authentication
BODY json

{
  "anchor_uuid": "",
  "image": [
    {
      "attachment_public_uuid": "",
      "content_type": "",
      "height": 0,
      "width": 0
    }
  ],
  "style": "",
  "uuid": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"anchor_uuid\": \"\",\n  \"image\": [\n    {\n      \"attachment_public_uuid\": \"\",\n      \"content_type\": \"\",\n      \"height\": 0,\n      \"width\": 0\n    }\n  ],\n  \"style\": \"\",\n  \"uuid\": \"\"\n}");

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

(client/post "{{baseUrl}}/avatar" {:headers {:user-agent ""
                                                             :x-bunq-client-authentication ""}
                                                   :content-type :json
                                                   :form-params {:anchor_uuid ""
                                                                 :image [{:attachment_public_uuid ""
                                                                          :content_type ""
                                                                          :height 0
                                                                          :width 0}]
                                                                 :style ""
                                                                 :uuid ""}})
require "http/client"

url = "{{baseUrl}}/avatar"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"anchor_uuid\": \"\",\n  \"image\": [\n    {\n      \"attachment_public_uuid\": \"\",\n      \"content_type\": \"\",\n      \"height\": 0,\n      \"width\": 0\n    }\n  ],\n  \"style\": \"\",\n  \"uuid\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/avatar"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"anchor_uuid\": \"\",\n  \"image\": [\n    {\n      \"attachment_public_uuid\": \"\",\n      \"content_type\": \"\",\n      \"height\": 0,\n      \"width\": 0\n    }\n  ],\n  \"style\": \"\",\n  \"uuid\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/avatar");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"anchor_uuid\": \"\",\n  \"image\": [\n    {\n      \"attachment_public_uuid\": \"\",\n      \"content_type\": \"\",\n      \"height\": 0,\n      \"width\": 0\n    }\n  ],\n  \"style\": \"\",\n  \"uuid\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

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

	payload := strings.NewReader("{\n  \"anchor_uuid\": \"\",\n  \"image\": [\n    {\n      \"attachment_public_uuid\": \"\",\n      \"content_type\": \"\",\n      \"height\": 0,\n      \"width\": 0\n    }\n  ],\n  \"style\": \"\",\n  \"uuid\": \"\"\n}")

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

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

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

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

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

}
POST /baseUrl/avatar HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 180

{
  "anchor_uuid": "",
  "image": [
    {
      "attachment_public_uuid": "",
      "content_type": "",
      "height": 0,
      "width": 0
    }
  ],
  "style": "",
  "uuid": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/avatar")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"anchor_uuid\": \"\",\n  \"image\": [\n    {\n      \"attachment_public_uuid\": \"\",\n      \"content_type\": \"\",\n      \"height\": 0,\n      \"width\": 0\n    }\n  ],\n  \"style\": \"\",\n  \"uuid\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/avatar"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"anchor_uuid\": \"\",\n  \"image\": [\n    {\n      \"attachment_public_uuid\": \"\",\n      \"content_type\": \"\",\n      \"height\": 0,\n      \"width\": 0\n    }\n  ],\n  \"style\": \"\",\n  \"uuid\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"anchor_uuid\": \"\",\n  \"image\": [\n    {\n      \"attachment_public_uuid\": \"\",\n      \"content_type\": \"\",\n      \"height\": 0,\n      \"width\": 0\n    }\n  ],\n  \"style\": \"\",\n  \"uuid\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/avatar")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/avatar")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"anchor_uuid\": \"\",\n  \"image\": [\n    {\n      \"attachment_public_uuid\": \"\",\n      \"content_type\": \"\",\n      \"height\": 0,\n      \"width\": 0\n    }\n  ],\n  \"style\": \"\",\n  \"uuid\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  anchor_uuid: '',
  image: [
    {
      attachment_public_uuid: '',
      content_type: '',
      height: 0,
      width: 0
    }
  ],
  style: '',
  uuid: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/avatar');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/avatar',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    anchor_uuid: '',
    image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
    style: '',
    uuid: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/avatar';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/avatar',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "anchor_uuid": "",\n  "image": [\n    {\n      "attachment_public_uuid": "",\n      "content_type": "",\n      "height": 0,\n      "width": 0\n    }\n  ],\n  "style": "",\n  "uuid": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"anchor_uuid\": \"\",\n  \"image\": [\n    {\n      \"attachment_public_uuid\": \"\",\n      \"content_type\": \"\",\n      \"height\": 0,\n      \"width\": 0\n    }\n  ],\n  \"style\": \"\",\n  \"uuid\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/avatar")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/avatar',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

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

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

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

req.write(JSON.stringify({
  anchor_uuid: '',
  image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
  style: '',
  uuid: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/avatar',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    anchor_uuid: '',
    image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
    style: '',
    uuid: ''
  },
  json: true
};

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

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

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

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  anchor_uuid: '',
  image: [
    {
      attachment_public_uuid: '',
      content_type: '',
      height: 0,
      width: 0
    }
  ],
  style: '',
  uuid: ''
});

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}}/avatar',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    anchor_uuid: '',
    image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
    style: '',
    uuid: ''
  }
};

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

const url = '{{baseUrl}}/avatar';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""}'
};

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

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"anchor_uuid": @"",
                              @"image": @[ @{ @"attachment_public_uuid": @"", @"content_type": @"", @"height": @0, @"width": @0 } ],
                              @"style": @"",
                              @"uuid": @"" };

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

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

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

let uri = Uri.of_string "{{baseUrl}}/avatar" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"anchor_uuid\": \"\",\n  \"image\": [\n    {\n      \"attachment_public_uuid\": \"\",\n      \"content_type\": \"\",\n      \"height\": 0,\n      \"width\": 0\n    }\n  ],\n  \"style\": \"\",\n  \"uuid\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/avatar",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'anchor_uuid' => '',
    'image' => [
        [
                'attachment_public_uuid' => '',
                'content_type' => '',
                'height' => 0,
                'width' => 0
        ]
    ],
    'style' => '',
    'uuid' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/avatar', [
  'body' => '{
  "anchor_uuid": "",
  "image": [
    {
      "attachment_public_uuid": "",
      "content_type": "",
      "height": 0,
      "width": 0
    }
  ],
  "style": "",
  "uuid": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

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

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'anchor_uuid' => '',
  'image' => [
    [
        'attachment_public_uuid' => '',
        'content_type' => '',
        'height' => 0,
        'width' => 0
    ]
  ],
  'style' => '',
  'uuid' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'anchor_uuid' => '',
  'image' => [
    [
        'attachment_public_uuid' => '',
        'content_type' => '',
        'height' => 0,
        'width' => 0
    ]
  ],
  'style' => '',
  'uuid' => ''
]));
$request->setRequestUrl('{{baseUrl}}/avatar');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/avatar' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "anchor_uuid": "",
  "image": [
    {
      "attachment_public_uuid": "",
      "content_type": "",
      "height": 0,
      "width": 0
    }
  ],
  "style": "",
  "uuid": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/avatar' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "anchor_uuid": "",
  "image": [
    {
      "attachment_public_uuid": "",
      "content_type": "",
      "height": 0,
      "width": 0
    }
  ],
  "style": "",
  "uuid": ""
}'
import http.client

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

payload = "{\n  \"anchor_uuid\": \"\",\n  \"image\": [\n    {\n      \"attachment_public_uuid\": \"\",\n      \"content_type\": \"\",\n      \"height\": 0,\n      \"width\": 0\n    }\n  ],\n  \"style\": \"\",\n  \"uuid\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

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

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

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

url = "{{baseUrl}}/avatar"

payload = {
    "anchor_uuid": "",
    "image": [
        {
            "attachment_public_uuid": "",
            "content_type": "",
            "height": 0,
            "width": 0
        }
    ],
    "style": "",
    "uuid": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

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

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

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

payload <- "{\n  \"anchor_uuid\": \"\",\n  \"image\": [\n    {\n      \"attachment_public_uuid\": \"\",\n      \"content_type\": \"\",\n      \"height\": 0,\n      \"width\": 0\n    }\n  ],\n  \"style\": \"\",\n  \"uuid\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

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

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

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

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"anchor_uuid\": \"\",\n  \"image\": [\n    {\n      \"attachment_public_uuid\": \"\",\n      \"content_type\": \"\",\n      \"height\": 0,\n      \"width\": 0\n    }\n  ],\n  \"style\": \"\",\n  \"uuid\": \"\"\n}"

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

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

response = conn.post('/baseUrl/avatar') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"anchor_uuid\": \"\",\n  \"image\": [\n    {\n      \"attachment_public_uuid\": \"\",\n      \"content_type\": \"\",\n      \"height\": 0,\n      \"width\": 0\n    }\n  ],\n  \"style\": \"\",\n  \"uuid\": \"\"\n}"
end

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

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

    let payload = json!({
        "anchor_uuid": "",
        "image": (
            json!({
                "attachment_public_uuid": "",
                "content_type": "",
                "height": 0,
                "width": 0
            })
        ),
        "style": "",
        "uuid": ""
    });

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/avatar \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "anchor_uuid": "",
  "image": [
    {
      "attachment_public_uuid": "",
      "content_type": "",
      "height": 0,
      "width": 0
    }
  ],
  "style": "",
  "uuid": ""
}'
echo '{
  "anchor_uuid": "",
  "image": [
    {
      "attachment_public_uuid": "",
      "content_type": "",
      "height": 0,
      "width": 0
    }
  ],
  "style": "",
  "uuid": ""
}' |  \
  http POST {{baseUrl}}/avatar \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "anchor_uuid": "",\n  "image": [\n    {\n      "attachment_public_uuid": "",\n      "content_type": "",\n      "height": 0,\n      "width": 0\n    }\n  ],\n  "style": "",\n  "uuid": ""\n}' \
  --output-document \
  - {{baseUrl}}/avatar
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "anchor_uuid": "",
  "image": [
    [
      "attachment_public_uuid": "",
      "content_type": "",
      "height": 0,
      "width": 0
    ]
  ],
  "style": "",
  "uuid": ""
] as [String : Any]

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

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

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

dataTask.resume()
GET READ_Avatar
{{baseUrl}}/avatar/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/avatar/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/avatar/:itemId" {:headers {:user-agent ""
                                                                    :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/avatar/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/avatar/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/avatar/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/avatar/:itemId"

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

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

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

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

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

}
GET /baseUrl/avatar/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/avatar/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/avatar/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/avatar/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/avatar/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/avatar/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/avatar/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/avatar/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/avatar/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/avatar/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/avatar/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

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

  res.on('data', function (chunk) {
    chunks.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}}/avatar/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

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

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

const req = unirest('GET', '{{baseUrl}}/avatar/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/avatar/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

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

const url = '{{baseUrl}}/avatar/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

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

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/avatar/:itemId"]
                                                       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}}/avatar/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/avatar/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

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

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/avatar/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/avatar/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/avatar/:itemId' -Method GET -Headers $headers
import http.client

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

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/avatar/:itemId", headers=headers)

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

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

url = "{{baseUrl}}/avatar/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

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

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

url <- "{{baseUrl}}/avatar/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/avatar/:itemId")

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

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

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

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

response = conn.get('/baseUrl/avatar/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

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

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".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}}/avatar/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/avatar/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/avatar/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

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

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

dataTask.resume()
GET List_all_BillingContractSubscription_for_User
{{baseUrl}}/user/:userID/billing-contract-subscription
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/billing-contract-subscription");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/user/:userID/billing-contract-subscription" {:headers {:user-agent ""
                                                                                                :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/billing-contract-subscription"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/billing-contract-subscription"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/billing-contract-subscription");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/user/:userID/billing-contract-subscription"

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

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

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

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

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

}
GET /baseUrl/user/:userID/billing-contract-subscription HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/billing-contract-subscription")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/billing-contract-subscription"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/billing-contract-subscription")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/billing-contract-subscription")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/user/:userID/billing-contract-subscription');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/billing-contract-subscription',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/billing-contract-subscription';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/billing-contract-subscription',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/billing-contract-subscription")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/billing-contract-subscription',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/billing-contract-subscription',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

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

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

const req = unirest('GET', '{{baseUrl}}/user/:userID/billing-contract-subscription');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/billing-contract-subscription',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

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

const url = '{{baseUrl}}/user/:userID/billing-contract-subscription';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

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

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/billing-contract-subscription"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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

let uri = Uri.of_string "{{baseUrl}}/user/:userID/billing-contract-subscription" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/billing-contract-subscription",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/billing-contract-subscription', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/billing-contract-subscription');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/billing-contract-subscription');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/billing-contract-subscription' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/billing-contract-subscription' -Method GET -Headers $headers
import http.client

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

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/billing-contract-subscription", headers=headers)

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

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

url = "{{baseUrl}}/user/:userID/billing-contract-subscription"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

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

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

url <- "{{baseUrl}}/user/:userID/billing-contract-subscription"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/user/:userID/billing-contract-subscription")

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

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

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

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

response = conn.get('/baseUrl/user/:userID/billing-contract-subscription') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/billing-contract-subscription";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/billing-contract-subscription \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/billing-contract-subscription \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/billing-contract-subscription
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/billing-contract-subscription")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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

dataTask.resume()
GET List_all_BunqmeFundraiserProfile_for_User
{{baseUrl}}/user/:userID/bunqme-fundraiser-profile
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/bunqme-fundraiser-profile");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/user/:userID/bunqme-fundraiser-profile" {:headers {:user-agent ""
                                                                                            :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/bunqme-fundraiser-profile"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/bunqme-fundraiser-profile"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/bunqme-fundraiser-profile");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/user/:userID/bunqme-fundraiser-profile"

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

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

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

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

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

}
GET /baseUrl/user/:userID/bunqme-fundraiser-profile HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/bunqme-fundraiser-profile")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/bunqme-fundraiser-profile"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/bunqme-fundraiser-profile")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/bunqme-fundraiser-profile")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/user/:userID/bunqme-fundraiser-profile');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/bunqme-fundraiser-profile',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/bunqme-fundraiser-profile';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/bunqme-fundraiser-profile',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/bunqme-fundraiser-profile")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/bunqme-fundraiser-profile',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/bunqme-fundraiser-profile',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

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

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

const req = unirest('GET', '{{baseUrl}}/user/:userID/bunqme-fundraiser-profile');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/bunqme-fundraiser-profile',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

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

const url = '{{baseUrl}}/user/:userID/bunqme-fundraiser-profile';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

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

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/bunqme-fundraiser-profile"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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

let uri = Uri.of_string "{{baseUrl}}/user/:userID/bunqme-fundraiser-profile" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/bunqme-fundraiser-profile",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/bunqme-fundraiser-profile', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/bunqme-fundraiser-profile');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/bunqme-fundraiser-profile');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/bunqme-fundraiser-profile' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/bunqme-fundraiser-profile' -Method GET -Headers $headers
import http.client

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

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/bunqme-fundraiser-profile", headers=headers)

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

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

url = "{{baseUrl}}/user/:userID/bunqme-fundraiser-profile"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

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

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

url <- "{{baseUrl}}/user/:userID/bunqme-fundraiser-profile"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/user/:userID/bunqme-fundraiser-profile")

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

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

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

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

response = conn.get('/baseUrl/user/:userID/bunqme-fundraiser-profile') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/bunqme-fundraiser-profile";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/bunqme-fundraiser-profile \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/bunqme-fundraiser-profile \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/bunqme-fundraiser-profile
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/bunqme-fundraiser-profile")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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

dataTask.resume()
GET READ_BunqmeFundraiserProfile_for_User
{{baseUrl}}/user/:userID/bunqme-fundraiser-profile/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/bunqme-fundraiser-profile/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/user/:userID/bunqme-fundraiser-profile/:itemId" {:headers {:user-agent ""
                                                                                                    :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/bunqme-fundraiser-profile/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/bunqme-fundraiser-profile/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/bunqme-fundraiser-profile/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/user/:userID/bunqme-fundraiser-profile/:itemId"

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

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

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

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

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

}
GET /baseUrl/user/:userID/bunqme-fundraiser-profile/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/bunqme-fundraiser-profile/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/bunqme-fundraiser-profile/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/bunqme-fundraiser-profile/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/bunqme-fundraiser-profile/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/user/:userID/bunqme-fundraiser-profile/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/bunqme-fundraiser-profile/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/bunqme-fundraiser-profile/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/bunqme-fundraiser-profile/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/bunqme-fundraiser-profile/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/bunqme-fundraiser-profile/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/bunqme-fundraiser-profile/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

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

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

const req = unirest('GET', '{{baseUrl}}/user/:userID/bunqme-fundraiser-profile/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/bunqme-fundraiser-profile/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

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

const url = '{{baseUrl}}/user/:userID/bunqme-fundraiser-profile/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

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

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/bunqme-fundraiser-profile/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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

let uri = Uri.of_string "{{baseUrl}}/user/:userID/bunqme-fundraiser-profile/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/bunqme-fundraiser-profile/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/bunqme-fundraiser-profile/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/bunqme-fundraiser-profile/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/bunqme-fundraiser-profile/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/bunqme-fundraiser-profile/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/bunqme-fundraiser-profile/:itemId' -Method GET -Headers $headers
import http.client

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

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/bunqme-fundraiser-profile/:itemId", headers=headers)

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

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

url = "{{baseUrl}}/user/:userID/bunqme-fundraiser-profile/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

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

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

url <- "{{baseUrl}}/user/:userID/bunqme-fundraiser-profile/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/user/:userID/bunqme-fundraiser-profile/:itemId")

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

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

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

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

response = conn.get('/baseUrl/user/:userID/bunqme-fundraiser-profile/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/bunqme-fundraiser-profile/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/bunqme-fundraiser-profile/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/bunqme-fundraiser-profile/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/bunqme-fundraiser-profile/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/bunqme-fundraiser-profile/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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

dataTask.resume()
GET READ_BunqmeFundraiserResult_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:itemId" {:headers {:user-agent ""
                                                                                                                                        :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:itemId"

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

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

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

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

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

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

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

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

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

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

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

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

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:itemId' -Method GET -Headers $headers
import http.client

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

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:itemId", headers=headers)

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

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

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

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

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

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:itemId")

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

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

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

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

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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

dataTask.resume()
POST CREATE_BunqmeTab_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
BODY json

{
  "bunqme_tab_entry": {
    "alias": {
      "avatar": {
        "anchor_uuid": "",
        "image": [
          {
            "attachment_public_uuid": "",
            "content_type": "",
            "height": 0,
            "width": 0
          }
        ],
        "style": "",
        "uuid": ""
      },
      "bunq_me": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "country": "",
      "display_name": "",
      "iban": "",
      "is_light": false,
      "label_user": {
        "avatar": {},
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "merchant_category_code": "",
      "swift_account_number": "",
      "swift_bic": "",
      "transferwise_account_number": "",
      "transferwise_bank_code": ""
    },
    "amount_inquired": {
      "currency": "",
      "value": ""
    },
    "description": "",
    "invite_profile_name": "",
    "merchant_available": [
      {
        "available": false,
        "merchant_type": ""
      }
    ],
    "redirect_url": "",
    "status": "",
    "uuid": ""
  },
  "status": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"bunqme_tab_entry\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"amount_inquired\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"description\": \"\",\n    \"invite_profile_name\": \"\",\n    \"merchant_available\": [\n      {\n        \"available\": false,\n        \"merchant_type\": \"\"\n      }\n    ],\n    \"redirect_url\": \"\",\n    \"status\": \"\",\n    \"uuid\": \"\"\n  },\n  \"status\": \"\"\n}");

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

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab" {:headers {:user-agent ""
                                                                                                                   :x-bunq-client-authentication ""}
                                                                                                         :content-type :json
                                                                                                         :form-params {:bunqme_tab_entry {:alias {:avatar {:anchor_uuid ""
                                                                                                                                                           :image [{:attachment_public_uuid ""
                                                                                                                                                                    :content_type ""
                                                                                                                                                                    :height 0
                                                                                                                                                                    :width 0}]
                                                                                                                                                           :style ""
                                                                                                                                                           :uuid ""}
                                                                                                                                                  :bunq_me {:name ""
                                                                                                                                                            :service ""
                                                                                                                                                            :type ""
                                                                                                                                                            :value ""}
                                                                                                                                                  :country ""
                                                                                                                                                  :display_name ""
                                                                                                                                                  :iban ""
                                                                                                                                                  :is_light false
                                                                                                                                                  :label_user {:avatar {}
                                                                                                                                                               :country ""
                                                                                                                                                               :display_name ""
                                                                                                                                                               :public_nick_name ""
                                                                                                                                                               :uuid ""}
                                                                                                                                                  :merchant_category_code ""
                                                                                                                                                  :swift_account_number ""
                                                                                                                                                  :swift_bic ""
                                                                                                                                                  :transferwise_account_number ""
                                                                                                                                                  :transferwise_bank_code ""}
                                                                                                                                          :amount_inquired {:currency ""
                                                                                                                                                            :value ""}
                                                                                                                                          :description ""
                                                                                                                                          :invite_profile_name ""
                                                                                                                                          :merchant_available [{:available false
                                                                                                                                                                :merchant_type ""}]
                                                                                                                                          :redirect_url ""
                                                                                                                                          :status ""
                                                                                                                                          :uuid ""}
                                                                                                                       :status ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"bunqme_tab_entry\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"amount_inquired\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"description\": \"\",\n    \"invite_profile_name\": \"\",\n    \"merchant_available\": [\n      {\n        \"available\": false,\n        \"merchant_type\": \"\"\n      }\n    ],\n    \"redirect_url\": \"\",\n    \"status\": \"\",\n    \"uuid\": \"\"\n  },\n  \"status\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"bunqme_tab_entry\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"amount_inquired\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"description\": \"\",\n    \"invite_profile_name\": \"\",\n    \"merchant_available\": [\n      {\n        \"available\": false,\n        \"merchant_type\": \"\"\n      }\n    ],\n    \"redirect_url\": \"\",\n    \"status\": \"\",\n    \"uuid\": \"\"\n  },\n  \"status\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"bunqme_tab_entry\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"amount_inquired\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"description\": \"\",\n    \"invite_profile_name\": \"\",\n    \"merchant_available\": [\n      {\n        \"available\": false,\n        \"merchant_type\": \"\"\n      }\n    ],\n    \"redirect_url\": \"\",\n    \"status\": \"\",\n    \"uuid\": \"\"\n  },\n  \"status\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab"

	payload := strings.NewReader("{\n  \"bunqme_tab_entry\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"amount_inquired\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"description\": \"\",\n    \"invite_profile_name\": \"\",\n    \"merchant_available\": [\n      {\n        \"available\": false,\n        \"merchant_type\": \"\"\n      }\n    ],\n    \"redirect_url\": \"\",\n    \"status\": \"\",\n    \"uuid\": \"\"\n  },\n  \"status\": \"\"\n}")

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

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

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

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

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

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-tab HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 1154

{
  "bunqme_tab_entry": {
    "alias": {
      "avatar": {
        "anchor_uuid": "",
        "image": [
          {
            "attachment_public_uuid": "",
            "content_type": "",
            "height": 0,
            "width": 0
          }
        ],
        "style": "",
        "uuid": ""
      },
      "bunq_me": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "country": "",
      "display_name": "",
      "iban": "",
      "is_light": false,
      "label_user": {
        "avatar": {},
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "merchant_category_code": "",
      "swift_account_number": "",
      "swift_bic": "",
      "transferwise_account_number": "",
      "transferwise_bank_code": ""
    },
    "amount_inquired": {
      "currency": "",
      "value": ""
    },
    "description": "",
    "invite_profile_name": "",
    "merchant_available": [
      {
        "available": false,
        "merchant_type": ""
      }
    ],
    "redirect_url": "",
    "status": "",
    "uuid": ""
  },
  "status": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"bunqme_tab_entry\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"amount_inquired\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"description\": \"\",\n    \"invite_profile_name\": \"\",\n    \"merchant_available\": [\n      {\n        \"available\": false,\n        \"merchant_type\": \"\"\n      }\n    ],\n    \"redirect_url\": \"\",\n    \"status\": \"\",\n    \"uuid\": \"\"\n  },\n  \"status\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"bunqme_tab_entry\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"amount_inquired\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"description\": \"\",\n    \"invite_profile_name\": \"\",\n    \"merchant_available\": [\n      {\n        \"available\": false,\n        \"merchant_type\": \"\"\n      }\n    ],\n    \"redirect_url\": \"\",\n    \"status\": \"\",\n    \"uuid\": \"\"\n  },\n  \"status\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"bunqme_tab_entry\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"amount_inquired\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"description\": \"\",\n    \"invite_profile_name\": \"\",\n    \"merchant_available\": [\n      {\n        \"available\": false,\n        \"merchant_type\": \"\"\n      }\n    ],\n    \"redirect_url\": \"\",\n    \"status\": \"\",\n    \"uuid\": \"\"\n  },\n  \"status\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"bunqme_tab_entry\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"amount_inquired\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"description\": \"\",\n    \"invite_profile_name\": \"\",\n    \"merchant_available\": [\n      {\n        \"available\": false,\n        \"merchant_type\": \"\"\n      }\n    ],\n    \"redirect_url\": \"\",\n    \"status\": \"\",\n    \"uuid\": \"\"\n  },\n  \"status\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  bunqme_tab_entry: {
    alias: {
      avatar: {
        anchor_uuid: '',
        image: [
          {
            attachment_public_uuid: '',
            content_type: '',
            height: 0,
            width: 0
          }
        ],
        style: '',
        uuid: ''
      },
      bunq_me: {
        name: '',
        service: '',
        type: '',
        value: ''
      },
      country: '',
      display_name: '',
      iban: '',
      is_light: false,
      label_user: {
        avatar: {},
        country: '',
        display_name: '',
        public_nick_name: '',
        uuid: ''
      },
      merchant_category_code: '',
      swift_account_number: '',
      swift_bic: '',
      transferwise_account_number: '',
      transferwise_bank_code: ''
    },
    amount_inquired: {
      currency: '',
      value: ''
    },
    description: '',
    invite_profile_name: '',
    merchant_available: [
      {
        available: false,
        merchant_type: ''
      }
    ],
    redirect_url: '',
    status: '',
    uuid: ''
  },
  status: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    bunqme_tab_entry: {
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
          style: '',
          uuid: ''
        },
        bunq_me: {name: '', service: '', type: '', value: ''},
        country: '',
        display_name: '',
        iban: '',
        is_light: false,
        label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
        merchant_category_code: '',
        swift_account_number: '',
        swift_bic: '',
        transferwise_account_number: '',
        transferwise_bank_code: ''
      },
      amount_inquired: {currency: '', value: ''},
      description: '',
      invite_profile_name: '',
      merchant_available: [{available: false, merchant_type: ''}],
      redirect_url: '',
      status: '',
      uuid: ''
    },
    status: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"bunqme_tab_entry":{"alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"amount_inquired":{"currency":"","value":""},"description":"","invite_profile_name":"","merchant_available":[{"available":false,"merchant_type":""}],"redirect_url":"","status":"","uuid":""},"status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "bunqme_tab_entry": {\n    "alias": {\n      "avatar": {\n        "anchor_uuid": "",\n        "image": [\n          {\n            "attachment_public_uuid": "",\n            "content_type": "",\n            "height": 0,\n            "width": 0\n          }\n        ],\n        "style": "",\n        "uuid": ""\n      },\n      "bunq_me": {\n        "name": "",\n        "service": "",\n        "type": "",\n        "value": ""\n      },\n      "country": "",\n      "display_name": "",\n      "iban": "",\n      "is_light": false,\n      "label_user": {\n        "avatar": {},\n        "country": "",\n        "display_name": "",\n        "public_nick_name": "",\n        "uuid": ""\n      },\n      "merchant_category_code": "",\n      "swift_account_number": "",\n      "swift_bic": "",\n      "transferwise_account_number": "",\n      "transferwise_bank_code": ""\n    },\n    "amount_inquired": {\n      "currency": "",\n      "value": ""\n    },\n    "description": "",\n    "invite_profile_name": "",\n    "merchant_available": [\n      {\n        "available": false,\n        "merchant_type": ""\n      }\n    ],\n    "redirect_url": "",\n    "status": "",\n    "uuid": ""\n  },\n  "status": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"bunqme_tab_entry\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"amount_inquired\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"description\": \"\",\n    \"invite_profile_name\": \"\",\n    \"merchant_available\": [\n      {\n        \"available\": false,\n        \"merchant_type\": \"\"\n      }\n    ],\n    \"redirect_url\": \"\",\n    \"status\": \"\",\n    \"uuid\": \"\"\n  },\n  \"status\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-tab',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

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

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

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

req.write(JSON.stringify({
  bunqme_tab_entry: {
    alias: {
      avatar: {
        anchor_uuid: '',
        image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
        style: '',
        uuid: ''
      },
      bunq_me: {name: '', service: '', type: '', value: ''},
      country: '',
      display_name: '',
      iban: '',
      is_light: false,
      label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
      merchant_category_code: '',
      swift_account_number: '',
      swift_bic: '',
      transferwise_account_number: '',
      transferwise_bank_code: ''
    },
    amount_inquired: {currency: '', value: ''},
    description: '',
    invite_profile_name: '',
    merchant_available: [{available: false, merchant_type: ''}],
    redirect_url: '',
    status: '',
    uuid: ''
  },
  status: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    bunqme_tab_entry: {
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
          style: '',
          uuid: ''
        },
        bunq_me: {name: '', service: '', type: '', value: ''},
        country: '',
        display_name: '',
        iban: '',
        is_light: false,
        label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
        merchant_category_code: '',
        swift_account_number: '',
        swift_bic: '',
        transferwise_account_number: '',
        transferwise_bank_code: ''
      },
      amount_inquired: {currency: '', value: ''},
      description: '',
      invite_profile_name: '',
      merchant_available: [{available: false, merchant_type: ''}],
      redirect_url: '',
      status: '',
      uuid: ''
    },
    status: ''
  },
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  bunqme_tab_entry: {
    alias: {
      avatar: {
        anchor_uuid: '',
        image: [
          {
            attachment_public_uuid: '',
            content_type: '',
            height: 0,
            width: 0
          }
        ],
        style: '',
        uuid: ''
      },
      bunq_me: {
        name: '',
        service: '',
        type: '',
        value: ''
      },
      country: '',
      display_name: '',
      iban: '',
      is_light: false,
      label_user: {
        avatar: {},
        country: '',
        display_name: '',
        public_nick_name: '',
        uuid: ''
      },
      merchant_category_code: '',
      swift_account_number: '',
      swift_bic: '',
      transferwise_account_number: '',
      transferwise_bank_code: ''
    },
    amount_inquired: {
      currency: '',
      value: ''
    },
    description: '',
    invite_profile_name: '',
    merchant_available: [
      {
        available: false,
        merchant_type: ''
      }
    ],
    redirect_url: '',
    status: '',
    uuid: ''
  },
  status: ''
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    bunqme_tab_entry: {
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
          style: '',
          uuid: ''
        },
        bunq_me: {name: '', service: '', type: '', value: ''},
        country: '',
        display_name: '',
        iban: '',
        is_light: false,
        label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
        merchant_category_code: '',
        swift_account_number: '',
        swift_bic: '',
        transferwise_account_number: '',
        transferwise_bank_code: ''
      },
      amount_inquired: {currency: '', value: ''},
      description: '',
      invite_profile_name: '',
      merchant_available: [{available: false, merchant_type: ''}],
      redirect_url: '',
      status: '',
      uuid: ''
    },
    status: ''
  }
};

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

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"bunqme_tab_entry":{"alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"amount_inquired":{"currency":"","value":""},"description":"","invite_profile_name":"","merchant_available":[{"available":false,"merchant_type":""}],"redirect_url":"","status":"","uuid":""},"status":""}'
};

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

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"bunqme_tab_entry": @{ @"alias": @{ @"avatar": @{ @"anchor_uuid": @"", @"image": @[ @{ @"attachment_public_uuid": @"", @"content_type": @"", @"height": @0, @"width": @0 } ], @"style": @"", @"uuid": @"" }, @"bunq_me": @{ @"name": @"", @"service": @"", @"type": @"", @"value": @"" }, @"country": @"", @"display_name": @"", @"iban": @"", @"is_light": @NO, @"label_user": @{ @"avatar": @{  }, @"country": @"", @"display_name": @"", @"public_nick_name": @"", @"uuid": @"" }, @"merchant_category_code": @"", @"swift_account_number": @"", @"swift_bic": @"", @"transferwise_account_number": @"", @"transferwise_bank_code": @"" }, @"amount_inquired": @{ @"currency": @"", @"value": @"" }, @"description": @"", @"invite_profile_name": @"", @"merchant_available": @[ @{ @"available": @NO, @"merchant_type": @"" } ], @"redirect_url": @"", @"status": @"", @"uuid": @"" },
                              @"status": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

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

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"bunqme_tab_entry\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"amount_inquired\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"description\": \"\",\n    \"invite_profile_name\": \"\",\n    \"merchant_available\": [\n      {\n        \"available\": false,\n        \"merchant_type\": \"\"\n      }\n    ],\n    \"redirect_url\": \"\",\n    \"status\": \"\",\n    \"uuid\": \"\"\n  },\n  \"status\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'bunqme_tab_entry' => [
        'alias' => [
                'avatar' => [
                                'anchor_uuid' => '',
                                'image' => [
                                                                [
                                                                                                                                'attachment_public_uuid' => '',
                                                                                                                                'content_type' => '',
                                                                                                                                'height' => 0,
                                                                                                                                'width' => 0
                                                                ]
                                ],
                                'style' => '',
                                'uuid' => ''
                ],
                'bunq_me' => [
                                'name' => '',
                                'service' => '',
                                'type' => '',
                                'value' => ''
                ],
                'country' => '',
                'display_name' => '',
                'iban' => '',
                'is_light' => null,
                'label_user' => [
                                'avatar' => [
                                                                
                                ],
                                'country' => '',
                                'display_name' => '',
                                'public_nick_name' => '',
                                'uuid' => ''
                ],
                'merchant_category_code' => '',
                'swift_account_number' => '',
                'swift_bic' => '',
                'transferwise_account_number' => '',
                'transferwise_bank_code' => ''
        ],
        'amount_inquired' => [
                'currency' => '',
                'value' => ''
        ],
        'description' => '',
        'invite_profile_name' => '',
        'merchant_available' => [
                [
                                'available' => null,
                                'merchant_type' => ''
                ]
        ],
        'redirect_url' => '',
        'status' => '',
        'uuid' => ''
    ],
    'status' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab', [
  'body' => '{
  "bunqme_tab_entry": {
    "alias": {
      "avatar": {
        "anchor_uuid": "",
        "image": [
          {
            "attachment_public_uuid": "",
            "content_type": "",
            "height": 0,
            "width": 0
          }
        ],
        "style": "",
        "uuid": ""
      },
      "bunq_me": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "country": "",
      "display_name": "",
      "iban": "",
      "is_light": false,
      "label_user": {
        "avatar": {},
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "merchant_category_code": "",
      "swift_account_number": "",
      "swift_bic": "",
      "transferwise_account_number": "",
      "transferwise_bank_code": ""
    },
    "amount_inquired": {
      "currency": "",
      "value": ""
    },
    "description": "",
    "invite_profile_name": "",
    "merchant_available": [
      {
        "available": false,
        "merchant_type": ""
      }
    ],
    "redirect_url": "",
    "status": "",
    "uuid": ""
  },
  "status": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'bunqme_tab_entry' => [
    'alias' => [
        'avatar' => [
                'anchor_uuid' => '',
                'image' => [
                                [
                                                                'attachment_public_uuid' => '',
                                                                'content_type' => '',
                                                                'height' => 0,
                                                                'width' => 0
                                ]
                ],
                'style' => '',
                'uuid' => ''
        ],
        'bunq_me' => [
                'name' => '',
                'service' => '',
                'type' => '',
                'value' => ''
        ],
        'country' => '',
        'display_name' => '',
        'iban' => '',
        'is_light' => null,
        'label_user' => [
                'avatar' => [
                                
                ],
                'country' => '',
                'display_name' => '',
                'public_nick_name' => '',
                'uuid' => ''
        ],
        'merchant_category_code' => '',
        'swift_account_number' => '',
        'swift_bic' => '',
        'transferwise_account_number' => '',
        'transferwise_bank_code' => ''
    ],
    'amount_inquired' => [
        'currency' => '',
        'value' => ''
    ],
    'description' => '',
    'invite_profile_name' => '',
    'merchant_available' => [
        [
                'available' => null,
                'merchant_type' => ''
        ]
    ],
    'redirect_url' => '',
    'status' => '',
    'uuid' => ''
  ],
  'status' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'bunqme_tab_entry' => [
    'alias' => [
        'avatar' => [
                'anchor_uuid' => '',
                'image' => [
                                [
                                                                'attachment_public_uuid' => '',
                                                                'content_type' => '',
                                                                'height' => 0,
                                                                'width' => 0
                                ]
                ],
                'style' => '',
                'uuid' => ''
        ],
        'bunq_me' => [
                'name' => '',
                'service' => '',
                'type' => '',
                'value' => ''
        ],
        'country' => '',
        'display_name' => '',
        'iban' => '',
        'is_light' => null,
        'label_user' => [
                'avatar' => [
                                
                ],
                'country' => '',
                'display_name' => '',
                'public_nick_name' => '',
                'uuid' => ''
        ],
        'merchant_category_code' => '',
        'swift_account_number' => '',
        'swift_bic' => '',
        'transferwise_account_number' => '',
        'transferwise_bank_code' => ''
    ],
    'amount_inquired' => [
        'currency' => '',
        'value' => ''
    ],
    'description' => '',
    'invite_profile_name' => '',
    'merchant_available' => [
        [
                'available' => null,
                'merchant_type' => ''
        ]
    ],
    'redirect_url' => '',
    'status' => '',
    'uuid' => ''
  ],
  'status' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "bunqme_tab_entry": {
    "alias": {
      "avatar": {
        "anchor_uuid": "",
        "image": [
          {
            "attachment_public_uuid": "",
            "content_type": "",
            "height": 0,
            "width": 0
          }
        ],
        "style": "",
        "uuid": ""
      },
      "bunq_me": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "country": "",
      "display_name": "",
      "iban": "",
      "is_light": false,
      "label_user": {
        "avatar": {},
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "merchant_category_code": "",
      "swift_account_number": "",
      "swift_bic": "",
      "transferwise_account_number": "",
      "transferwise_bank_code": ""
    },
    "amount_inquired": {
      "currency": "",
      "value": ""
    },
    "description": "",
    "invite_profile_name": "",
    "merchant_available": [
      {
        "available": false,
        "merchant_type": ""
      }
    ],
    "redirect_url": "",
    "status": "",
    "uuid": ""
  },
  "status": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "bunqme_tab_entry": {
    "alias": {
      "avatar": {
        "anchor_uuid": "",
        "image": [
          {
            "attachment_public_uuid": "",
            "content_type": "",
            "height": 0,
            "width": 0
          }
        ],
        "style": "",
        "uuid": ""
      },
      "bunq_me": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "country": "",
      "display_name": "",
      "iban": "",
      "is_light": false,
      "label_user": {
        "avatar": {},
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "merchant_category_code": "",
      "swift_account_number": "",
      "swift_bic": "",
      "transferwise_account_number": "",
      "transferwise_bank_code": ""
    },
    "amount_inquired": {
      "currency": "",
      "value": ""
    },
    "description": "",
    "invite_profile_name": "",
    "merchant_available": [
      {
        "available": false,
        "merchant_type": ""
      }
    ],
    "redirect_url": "",
    "status": "",
    "uuid": ""
  },
  "status": ""
}'
import http.client

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

payload = "{\n  \"bunqme_tab_entry\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"amount_inquired\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"description\": \"\",\n    \"invite_profile_name\": \"\",\n    \"merchant_available\": [\n      {\n        \"available\": false,\n        \"merchant_type\": \"\"\n      }\n    ],\n    \"redirect_url\": \"\",\n    \"status\": \"\",\n    \"uuid\": \"\"\n  },\n  \"status\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-tab", payload, headers)

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

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

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab"

payload = {
    "bunqme_tab_entry": {
        "alias": {
            "avatar": {
                "anchor_uuid": "",
                "image": [
                    {
                        "attachment_public_uuid": "",
                        "content_type": "",
                        "height": 0,
                        "width": 0
                    }
                ],
                "style": "",
                "uuid": ""
            },
            "bunq_me": {
                "name": "",
                "service": "",
                "type": "",
                "value": ""
            },
            "country": "",
            "display_name": "",
            "iban": "",
            "is_light": False,
            "label_user": {
                "avatar": {},
                "country": "",
                "display_name": "",
                "public_nick_name": "",
                "uuid": ""
            },
            "merchant_category_code": "",
            "swift_account_number": "",
            "swift_bic": "",
            "transferwise_account_number": "",
            "transferwise_bank_code": ""
        },
        "amount_inquired": {
            "currency": "",
            "value": ""
        },
        "description": "",
        "invite_profile_name": "",
        "merchant_available": [
            {
                "available": False,
                "merchant_type": ""
            }
        ],
        "redirect_url": "",
        "status": "",
        "uuid": ""
    },
    "status": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab"

payload <- "{\n  \"bunqme_tab_entry\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"amount_inquired\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"description\": \"\",\n    \"invite_profile_name\": \"\",\n    \"merchant_available\": [\n      {\n        \"available\": false,\n        \"merchant_type\": \"\"\n      }\n    ],\n    \"redirect_url\": \"\",\n    \"status\": \"\",\n    \"uuid\": \"\"\n  },\n  \"status\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab")

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

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"bunqme_tab_entry\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"amount_inquired\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"description\": \"\",\n    \"invite_profile_name\": \"\",\n    \"merchant_available\": [\n      {\n        \"available\": false,\n        \"merchant_type\": \"\"\n      }\n    ],\n    \"redirect_url\": \"\",\n    \"status\": \"\",\n    \"uuid\": \"\"\n  },\n  \"status\": \"\"\n}"

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

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

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-tab') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"bunqme_tab_entry\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"amount_inquired\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"description\": \"\",\n    \"invite_profile_name\": \"\",\n    \"merchant_available\": [\n      {\n        \"available\": false,\n        \"merchant_type\": \"\"\n      }\n    ],\n    \"redirect_url\": \"\",\n    \"status\": \"\",\n    \"uuid\": \"\"\n  },\n  \"status\": \"\"\n}"
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab";

    let payload = json!({
        "bunqme_tab_entry": json!({
            "alias": json!({
                "avatar": json!({
                    "anchor_uuid": "",
                    "image": (
                        json!({
                            "attachment_public_uuid": "",
                            "content_type": "",
                            "height": 0,
                            "width": 0
                        })
                    ),
                    "style": "",
                    "uuid": ""
                }),
                "bunq_me": json!({
                    "name": "",
                    "service": "",
                    "type": "",
                    "value": ""
                }),
                "country": "",
                "display_name": "",
                "iban": "",
                "is_light": false,
                "label_user": json!({
                    "avatar": json!({}),
                    "country": "",
                    "display_name": "",
                    "public_nick_name": "",
                    "uuid": ""
                }),
                "merchant_category_code": "",
                "swift_account_number": "",
                "swift_bic": "",
                "transferwise_account_number": "",
                "transferwise_bank_code": ""
            }),
            "amount_inquired": json!({
                "currency": "",
                "value": ""
            }),
            "description": "",
            "invite_profile_name": "",
            "merchant_available": (
                json!({
                    "available": false,
                    "merchant_type": ""
                })
            ),
            "redirect_url": "",
            "status": "",
            "uuid": ""
        }),
        "status": ""
    });

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "bunqme_tab_entry": {
    "alias": {
      "avatar": {
        "anchor_uuid": "",
        "image": [
          {
            "attachment_public_uuid": "",
            "content_type": "",
            "height": 0,
            "width": 0
          }
        ],
        "style": "",
        "uuid": ""
      },
      "bunq_me": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "country": "",
      "display_name": "",
      "iban": "",
      "is_light": false,
      "label_user": {
        "avatar": {},
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "merchant_category_code": "",
      "swift_account_number": "",
      "swift_bic": "",
      "transferwise_account_number": "",
      "transferwise_bank_code": ""
    },
    "amount_inquired": {
      "currency": "",
      "value": ""
    },
    "description": "",
    "invite_profile_name": "",
    "merchant_available": [
      {
        "available": false,
        "merchant_type": ""
      }
    ],
    "redirect_url": "",
    "status": "",
    "uuid": ""
  },
  "status": ""
}'
echo '{
  "bunqme_tab_entry": {
    "alias": {
      "avatar": {
        "anchor_uuid": "",
        "image": [
          {
            "attachment_public_uuid": "",
            "content_type": "",
            "height": 0,
            "width": 0
          }
        ],
        "style": "",
        "uuid": ""
      },
      "bunq_me": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "country": "",
      "display_name": "",
      "iban": "",
      "is_light": false,
      "label_user": {
        "avatar": {},
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "merchant_category_code": "",
      "swift_account_number": "",
      "swift_bic": "",
      "transferwise_account_number": "",
      "transferwise_bank_code": ""
    },
    "amount_inquired": {
      "currency": "",
      "value": ""
    },
    "description": "",
    "invite_profile_name": "",
    "merchant_available": [
      {
        "available": false,
        "merchant_type": ""
      }
    ],
    "redirect_url": "",
    "status": "",
    "uuid": ""
  },
  "status": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "bunqme_tab_entry": {\n    "alias": {\n      "avatar": {\n        "anchor_uuid": "",\n        "image": [\n          {\n            "attachment_public_uuid": "",\n            "content_type": "",\n            "height": 0,\n            "width": 0\n          }\n        ],\n        "style": "",\n        "uuid": ""\n      },\n      "bunq_me": {\n        "name": "",\n        "service": "",\n        "type": "",\n        "value": ""\n      },\n      "country": "",\n      "display_name": "",\n      "iban": "",\n      "is_light": false,\n      "label_user": {\n        "avatar": {},\n        "country": "",\n        "display_name": "",\n        "public_nick_name": "",\n        "uuid": ""\n      },\n      "merchant_category_code": "",\n      "swift_account_number": "",\n      "swift_bic": "",\n      "transferwise_account_number": "",\n      "transferwise_bank_code": ""\n    },\n    "amount_inquired": {\n      "currency": "",\n      "value": ""\n    },\n    "description": "",\n    "invite_profile_name": "",\n    "merchant_available": [\n      {\n        "available": false,\n        "merchant_type": ""\n      }\n    ],\n    "redirect_url": "",\n    "status": "",\n    "uuid": ""\n  },\n  "status": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "bunqme_tab_entry": [
    "alias": [
      "avatar": [
        "anchor_uuid": "",
        "image": [
          [
            "attachment_public_uuid": "",
            "content_type": "",
            "height": 0,
            "width": 0
          ]
        ],
        "style": "",
        "uuid": ""
      ],
      "bunq_me": [
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      ],
      "country": "",
      "display_name": "",
      "iban": "",
      "is_light": false,
      "label_user": [
        "avatar": [],
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      ],
      "merchant_category_code": "",
      "swift_account_number": "",
      "swift_bic": "",
      "transferwise_account_number": "",
      "transferwise_bank_code": ""
    ],
    "amount_inquired": [
      "currency": "",
      "value": ""
    ],
    "description": "",
    "invite_profile_name": "",
    "merchant_available": [
      [
        "available": false,
        "merchant_type": ""
      ]
    ],
    "redirect_url": "",
    "status": "",
    "uuid": ""
  ],
  "status": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

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

dataTask.resume()
GET List_all_BunqmeTab_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab" {:headers {:user-agent ""
                                                                                                                  :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab"

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

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

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

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

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

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-tab HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-tab',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

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

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

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

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

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

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

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab' -Method GET -Headers $headers
import http.client

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

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-tab", headers=headers)

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

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

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

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

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

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab")

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

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

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

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

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-tab') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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

dataTask.resume()
GET READ_BunqmeTab_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId" {:headers {:user-agent ""
                                                                                                                          :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId"

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

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

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

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

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

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

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

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

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

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

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

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

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId' -Method GET -Headers $headers
import http.client

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

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId", headers=headers)

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

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

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

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

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

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId")

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

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

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

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

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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

dataTask.resume()
PUT UPDATE_BunqmeTab_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
itemId
BODY json

{
  "bunqme_tab_entry": {
    "alias": {
      "avatar": {
        "anchor_uuid": "",
        "image": [
          {
            "attachment_public_uuid": "",
            "content_type": "",
            "height": 0,
            "width": 0
          }
        ],
        "style": "",
        "uuid": ""
      },
      "bunq_me": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "country": "",
      "display_name": "",
      "iban": "",
      "is_light": false,
      "label_user": {
        "avatar": {},
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "merchant_category_code": "",
      "swift_account_number": "",
      "swift_bic": "",
      "transferwise_account_number": "",
      "transferwise_bank_code": ""
    },
    "amount_inquired": {
      "currency": "",
      "value": ""
    },
    "description": "",
    "invite_profile_name": "",
    "merchant_available": [
      {
        "available": false,
        "merchant_type": ""
      }
    ],
    "redirect_url": "",
    "status": "",
    "uuid": ""
  },
  "status": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"bunqme_tab_entry\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"amount_inquired\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"description\": \"\",\n    \"invite_profile_name\": \"\",\n    \"merchant_available\": [\n      {\n        \"available\": false,\n        \"merchant_type\": \"\"\n      }\n    ],\n    \"redirect_url\": \"\",\n    \"status\": \"\",\n    \"uuid\": \"\"\n  },\n  \"status\": \"\"\n}");

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

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId" {:headers {:user-agent ""
                                                                                                                          :x-bunq-client-authentication ""}
                                                                                                                :content-type :json
                                                                                                                :form-params {:bunqme_tab_entry {:alias {:avatar {:anchor_uuid ""
                                                                                                                                                                  :image [{:attachment_public_uuid ""
                                                                                                                                                                           :content_type ""
                                                                                                                                                                           :height 0
                                                                                                                                                                           :width 0}]
                                                                                                                                                                  :style ""
                                                                                                                                                                  :uuid ""}
                                                                                                                                                         :bunq_me {:name ""
                                                                                                                                                                   :service ""
                                                                                                                                                                   :type ""
                                                                                                                                                                   :value ""}
                                                                                                                                                         :country ""
                                                                                                                                                         :display_name ""
                                                                                                                                                         :iban ""
                                                                                                                                                         :is_light false
                                                                                                                                                         :label_user {:avatar {}
                                                                                                                                                                      :country ""
                                                                                                                                                                      :display_name ""
                                                                                                                                                                      :public_nick_name ""
                                                                                                                                                                      :uuid ""}
                                                                                                                                                         :merchant_category_code ""
                                                                                                                                                         :swift_account_number ""
                                                                                                                                                         :swift_bic ""
                                                                                                                                                         :transferwise_account_number ""
                                                                                                                                                         :transferwise_bank_code ""}
                                                                                                                                                 :amount_inquired {:currency ""
                                                                                                                                                                   :value ""}
                                                                                                                                                 :description ""
                                                                                                                                                 :invite_profile_name ""
                                                                                                                                                 :merchant_available [{:available false
                                                                                                                                                                       :merchant_type ""}]
                                                                                                                                                 :redirect_url ""
                                                                                                                                                 :status ""
                                                                                                                                                 :uuid ""}
                                                                                                                              :status ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"bunqme_tab_entry\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"amount_inquired\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"description\": \"\",\n    \"invite_profile_name\": \"\",\n    \"merchant_available\": [\n      {\n        \"available\": false,\n        \"merchant_type\": \"\"\n      }\n    ],\n    \"redirect_url\": \"\",\n    \"status\": \"\",\n    \"uuid\": \"\"\n  },\n  \"status\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"bunqme_tab_entry\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"amount_inquired\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"description\": \"\",\n    \"invite_profile_name\": \"\",\n    \"merchant_available\": [\n      {\n        \"available\": false,\n        \"merchant_type\": \"\"\n      }\n    ],\n    \"redirect_url\": \"\",\n    \"status\": \"\",\n    \"uuid\": \"\"\n  },\n  \"status\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"bunqme_tab_entry\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"amount_inquired\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"description\": \"\",\n    \"invite_profile_name\": \"\",\n    \"merchant_available\": [\n      {\n        \"available\": false,\n        \"merchant_type\": \"\"\n      }\n    ],\n    \"redirect_url\": \"\",\n    \"status\": \"\",\n    \"uuid\": \"\"\n  },\n  \"status\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId"

	payload := strings.NewReader("{\n  \"bunqme_tab_entry\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"amount_inquired\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"description\": \"\",\n    \"invite_profile_name\": \"\",\n    \"merchant_available\": [\n      {\n        \"available\": false,\n        \"merchant_type\": \"\"\n      }\n    ],\n    \"redirect_url\": \"\",\n    \"status\": \"\",\n    \"uuid\": \"\"\n  },\n  \"status\": \"\"\n}")

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

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

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

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

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

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 1154

{
  "bunqme_tab_entry": {
    "alias": {
      "avatar": {
        "anchor_uuid": "",
        "image": [
          {
            "attachment_public_uuid": "",
            "content_type": "",
            "height": 0,
            "width": 0
          }
        ],
        "style": "",
        "uuid": ""
      },
      "bunq_me": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "country": "",
      "display_name": "",
      "iban": "",
      "is_light": false,
      "label_user": {
        "avatar": {},
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "merchant_category_code": "",
      "swift_account_number": "",
      "swift_bic": "",
      "transferwise_account_number": "",
      "transferwise_bank_code": ""
    },
    "amount_inquired": {
      "currency": "",
      "value": ""
    },
    "description": "",
    "invite_profile_name": "",
    "merchant_available": [
      {
        "available": false,
        "merchant_type": ""
      }
    ],
    "redirect_url": "",
    "status": "",
    "uuid": ""
  },
  "status": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"bunqme_tab_entry\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"amount_inquired\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"description\": \"\",\n    \"invite_profile_name\": \"\",\n    \"merchant_available\": [\n      {\n        \"available\": false,\n        \"merchant_type\": \"\"\n      }\n    ],\n    \"redirect_url\": \"\",\n    \"status\": \"\",\n    \"uuid\": \"\"\n  },\n  \"status\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"bunqme_tab_entry\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"amount_inquired\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"description\": \"\",\n    \"invite_profile_name\": \"\",\n    \"merchant_available\": [\n      {\n        \"available\": false,\n        \"merchant_type\": \"\"\n      }\n    ],\n    \"redirect_url\": \"\",\n    \"status\": \"\",\n    \"uuid\": \"\"\n  },\n  \"status\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"bunqme_tab_entry\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"amount_inquired\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"description\": \"\",\n    \"invite_profile_name\": \"\",\n    \"merchant_available\": [\n      {\n        \"available\": false,\n        \"merchant_type\": \"\"\n      }\n    ],\n    \"redirect_url\": \"\",\n    \"status\": \"\",\n    \"uuid\": \"\"\n  },\n  \"status\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"bunqme_tab_entry\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"amount_inquired\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"description\": \"\",\n    \"invite_profile_name\": \"\",\n    \"merchant_available\": [\n      {\n        \"available\": false,\n        \"merchant_type\": \"\"\n      }\n    ],\n    \"redirect_url\": \"\",\n    \"status\": \"\",\n    \"uuid\": \"\"\n  },\n  \"status\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  bunqme_tab_entry: {
    alias: {
      avatar: {
        anchor_uuid: '',
        image: [
          {
            attachment_public_uuid: '',
            content_type: '',
            height: 0,
            width: 0
          }
        ],
        style: '',
        uuid: ''
      },
      bunq_me: {
        name: '',
        service: '',
        type: '',
        value: ''
      },
      country: '',
      display_name: '',
      iban: '',
      is_light: false,
      label_user: {
        avatar: {},
        country: '',
        display_name: '',
        public_nick_name: '',
        uuid: ''
      },
      merchant_category_code: '',
      swift_account_number: '',
      swift_bic: '',
      transferwise_account_number: '',
      transferwise_bank_code: ''
    },
    amount_inquired: {
      currency: '',
      value: ''
    },
    description: '',
    invite_profile_name: '',
    merchant_available: [
      {
        available: false,
        merchant_type: ''
      }
    ],
    redirect_url: '',
    status: '',
    uuid: ''
  },
  status: ''
});

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

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

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    bunqme_tab_entry: {
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
          style: '',
          uuid: ''
        },
        bunq_me: {name: '', service: '', type: '', value: ''},
        country: '',
        display_name: '',
        iban: '',
        is_light: false,
        label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
        merchant_category_code: '',
        swift_account_number: '',
        swift_bic: '',
        transferwise_account_number: '',
        transferwise_bank_code: ''
      },
      amount_inquired: {currency: '', value: ''},
      description: '',
      invite_profile_name: '',
      merchant_available: [{available: false, merchant_type: ''}],
      redirect_url: '',
      status: '',
      uuid: ''
    },
    status: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"bunqme_tab_entry":{"alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"amount_inquired":{"currency":"","value":""},"description":"","invite_profile_name":"","merchant_available":[{"available":false,"merchant_type":""}],"redirect_url":"","status":"","uuid":""},"status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "bunqme_tab_entry": {\n    "alias": {\n      "avatar": {\n        "anchor_uuid": "",\n        "image": [\n          {\n            "attachment_public_uuid": "",\n            "content_type": "",\n            "height": 0,\n            "width": 0\n          }\n        ],\n        "style": "",\n        "uuid": ""\n      },\n      "bunq_me": {\n        "name": "",\n        "service": "",\n        "type": "",\n        "value": ""\n      },\n      "country": "",\n      "display_name": "",\n      "iban": "",\n      "is_light": false,\n      "label_user": {\n        "avatar": {},\n        "country": "",\n        "display_name": "",\n        "public_nick_name": "",\n        "uuid": ""\n      },\n      "merchant_category_code": "",\n      "swift_account_number": "",\n      "swift_bic": "",\n      "transferwise_account_number": "",\n      "transferwise_bank_code": ""\n    },\n    "amount_inquired": {\n      "currency": "",\n      "value": ""\n    },\n    "description": "",\n    "invite_profile_name": "",\n    "merchant_available": [\n      {\n        "available": false,\n        "merchant_type": ""\n      }\n    ],\n    "redirect_url": "",\n    "status": "",\n    "uuid": ""\n  },\n  "status": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"bunqme_tab_entry\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"amount_inquired\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"description\": \"\",\n    \"invite_profile_name\": \"\",\n    \"merchant_available\": [\n      {\n        \"available\": false,\n        \"merchant_type\": \"\"\n      }\n    ],\n    \"redirect_url\": \"\",\n    \"status\": \"\",\n    \"uuid\": \"\"\n  },\n  \"status\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

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

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

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

req.write(JSON.stringify({
  bunqme_tab_entry: {
    alias: {
      avatar: {
        anchor_uuid: '',
        image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
        style: '',
        uuid: ''
      },
      bunq_me: {name: '', service: '', type: '', value: ''},
      country: '',
      display_name: '',
      iban: '',
      is_light: false,
      label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
      merchant_category_code: '',
      swift_account_number: '',
      swift_bic: '',
      transferwise_account_number: '',
      transferwise_bank_code: ''
    },
    amount_inquired: {currency: '', value: ''},
    description: '',
    invite_profile_name: '',
    merchant_available: [{available: false, merchant_type: ''}],
    redirect_url: '',
    status: '',
    uuid: ''
  },
  status: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    bunqme_tab_entry: {
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
          style: '',
          uuid: ''
        },
        bunq_me: {name: '', service: '', type: '', value: ''},
        country: '',
        display_name: '',
        iban: '',
        is_light: false,
        label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
        merchant_category_code: '',
        swift_account_number: '',
        swift_bic: '',
        transferwise_account_number: '',
        transferwise_bank_code: ''
      },
      amount_inquired: {currency: '', value: ''},
      description: '',
      invite_profile_name: '',
      merchant_available: [{available: false, merchant_type: ''}],
      redirect_url: '',
      status: '',
      uuid: ''
    },
    status: ''
  },
  json: true
};

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

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

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  bunqme_tab_entry: {
    alias: {
      avatar: {
        anchor_uuid: '',
        image: [
          {
            attachment_public_uuid: '',
            content_type: '',
            height: 0,
            width: 0
          }
        ],
        style: '',
        uuid: ''
      },
      bunq_me: {
        name: '',
        service: '',
        type: '',
        value: ''
      },
      country: '',
      display_name: '',
      iban: '',
      is_light: false,
      label_user: {
        avatar: {},
        country: '',
        display_name: '',
        public_nick_name: '',
        uuid: ''
      },
      merchant_category_code: '',
      swift_account_number: '',
      swift_bic: '',
      transferwise_account_number: '',
      transferwise_bank_code: ''
    },
    amount_inquired: {
      currency: '',
      value: ''
    },
    description: '',
    invite_profile_name: '',
    merchant_available: [
      {
        available: false,
        merchant_type: ''
      }
    ],
    redirect_url: '',
    status: '',
    uuid: ''
  },
  status: ''
});

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

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

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    bunqme_tab_entry: {
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
          style: '',
          uuid: ''
        },
        bunq_me: {name: '', service: '', type: '', value: ''},
        country: '',
        display_name: '',
        iban: '',
        is_light: false,
        label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
        merchant_category_code: '',
        swift_account_number: '',
        swift_bic: '',
        transferwise_account_number: '',
        transferwise_bank_code: ''
      },
      amount_inquired: {currency: '', value: ''},
      description: '',
      invite_profile_name: '',
      merchant_available: [{available: false, merchant_type: ''}],
      redirect_url: '',
      status: '',
      uuid: ''
    },
    status: ''
  }
};

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

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"bunqme_tab_entry":{"alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"amount_inquired":{"currency":"","value":""},"description":"","invite_profile_name":"","merchant_available":[{"available":false,"merchant_type":""}],"redirect_url":"","status":"","uuid":""},"status":""}'
};

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

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"bunqme_tab_entry": @{ @"alias": @{ @"avatar": @{ @"anchor_uuid": @"", @"image": @[ @{ @"attachment_public_uuid": @"", @"content_type": @"", @"height": @0, @"width": @0 } ], @"style": @"", @"uuid": @"" }, @"bunq_me": @{ @"name": @"", @"service": @"", @"type": @"", @"value": @"" }, @"country": @"", @"display_name": @"", @"iban": @"", @"is_light": @NO, @"label_user": @{ @"avatar": @{  }, @"country": @"", @"display_name": @"", @"public_nick_name": @"", @"uuid": @"" }, @"merchant_category_code": @"", @"swift_account_number": @"", @"swift_bic": @"", @"transferwise_account_number": @"", @"transferwise_bank_code": @"" }, @"amount_inquired": @{ @"currency": @"", @"value": @"" }, @"description": @"", @"invite_profile_name": @"", @"merchant_available": @[ @{ @"available": @NO, @"merchant_type": @"" } ], @"redirect_url": @"", @"status": @"", @"uuid": @"" },
                              @"status": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

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

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"bunqme_tab_entry\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"amount_inquired\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"description\": \"\",\n    \"invite_profile_name\": \"\",\n    \"merchant_available\": [\n      {\n        \"available\": false,\n        \"merchant_type\": \"\"\n      }\n    ],\n    \"redirect_url\": \"\",\n    \"status\": \"\",\n    \"uuid\": \"\"\n  },\n  \"status\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'bunqme_tab_entry' => [
        'alias' => [
                'avatar' => [
                                'anchor_uuid' => '',
                                'image' => [
                                                                [
                                                                                                                                'attachment_public_uuid' => '',
                                                                                                                                'content_type' => '',
                                                                                                                                'height' => 0,
                                                                                                                                'width' => 0
                                                                ]
                                ],
                                'style' => '',
                                'uuid' => ''
                ],
                'bunq_me' => [
                                'name' => '',
                                'service' => '',
                                'type' => '',
                                'value' => ''
                ],
                'country' => '',
                'display_name' => '',
                'iban' => '',
                'is_light' => null,
                'label_user' => [
                                'avatar' => [
                                                                
                                ],
                                'country' => '',
                                'display_name' => '',
                                'public_nick_name' => '',
                                'uuid' => ''
                ],
                'merchant_category_code' => '',
                'swift_account_number' => '',
                'swift_bic' => '',
                'transferwise_account_number' => '',
                'transferwise_bank_code' => ''
        ],
        'amount_inquired' => [
                'currency' => '',
                'value' => ''
        ],
        'description' => '',
        'invite_profile_name' => '',
        'merchant_available' => [
                [
                                'available' => null,
                                'merchant_type' => ''
                ]
        ],
        'redirect_url' => '',
        'status' => '',
        'uuid' => ''
    ],
    'status' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId', [
  'body' => '{
  "bunqme_tab_entry": {
    "alias": {
      "avatar": {
        "anchor_uuid": "",
        "image": [
          {
            "attachment_public_uuid": "",
            "content_type": "",
            "height": 0,
            "width": 0
          }
        ],
        "style": "",
        "uuid": ""
      },
      "bunq_me": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "country": "",
      "display_name": "",
      "iban": "",
      "is_light": false,
      "label_user": {
        "avatar": {},
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "merchant_category_code": "",
      "swift_account_number": "",
      "swift_bic": "",
      "transferwise_account_number": "",
      "transferwise_bank_code": ""
    },
    "amount_inquired": {
      "currency": "",
      "value": ""
    },
    "description": "",
    "invite_profile_name": "",
    "merchant_available": [
      {
        "available": false,
        "merchant_type": ""
      }
    ],
    "redirect_url": "",
    "status": "",
    "uuid": ""
  },
  "status": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'bunqme_tab_entry' => [
    'alias' => [
        'avatar' => [
                'anchor_uuid' => '',
                'image' => [
                                [
                                                                'attachment_public_uuid' => '',
                                                                'content_type' => '',
                                                                'height' => 0,
                                                                'width' => 0
                                ]
                ],
                'style' => '',
                'uuid' => ''
        ],
        'bunq_me' => [
                'name' => '',
                'service' => '',
                'type' => '',
                'value' => ''
        ],
        'country' => '',
        'display_name' => '',
        'iban' => '',
        'is_light' => null,
        'label_user' => [
                'avatar' => [
                                
                ],
                'country' => '',
                'display_name' => '',
                'public_nick_name' => '',
                'uuid' => ''
        ],
        'merchant_category_code' => '',
        'swift_account_number' => '',
        'swift_bic' => '',
        'transferwise_account_number' => '',
        'transferwise_bank_code' => ''
    ],
    'amount_inquired' => [
        'currency' => '',
        'value' => ''
    ],
    'description' => '',
    'invite_profile_name' => '',
    'merchant_available' => [
        [
                'available' => null,
                'merchant_type' => ''
        ]
    ],
    'redirect_url' => '',
    'status' => '',
    'uuid' => ''
  ],
  'status' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'bunqme_tab_entry' => [
    'alias' => [
        'avatar' => [
                'anchor_uuid' => '',
                'image' => [
                                [
                                                                'attachment_public_uuid' => '',
                                                                'content_type' => '',
                                                                'height' => 0,
                                                                'width' => 0
                                ]
                ],
                'style' => '',
                'uuid' => ''
        ],
        'bunq_me' => [
                'name' => '',
                'service' => '',
                'type' => '',
                'value' => ''
        ],
        'country' => '',
        'display_name' => '',
        'iban' => '',
        'is_light' => null,
        'label_user' => [
                'avatar' => [
                                
                ],
                'country' => '',
                'display_name' => '',
                'public_nick_name' => '',
                'uuid' => ''
        ],
        'merchant_category_code' => '',
        'swift_account_number' => '',
        'swift_bic' => '',
        'transferwise_account_number' => '',
        'transferwise_bank_code' => ''
    ],
    'amount_inquired' => [
        'currency' => '',
        'value' => ''
    ],
    'description' => '',
    'invite_profile_name' => '',
    'merchant_available' => [
        [
                'available' => null,
                'merchant_type' => ''
        ]
    ],
    'redirect_url' => '',
    'status' => '',
    'uuid' => ''
  ],
  'status' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "bunqme_tab_entry": {
    "alias": {
      "avatar": {
        "anchor_uuid": "",
        "image": [
          {
            "attachment_public_uuid": "",
            "content_type": "",
            "height": 0,
            "width": 0
          }
        ],
        "style": "",
        "uuid": ""
      },
      "bunq_me": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "country": "",
      "display_name": "",
      "iban": "",
      "is_light": false,
      "label_user": {
        "avatar": {},
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "merchant_category_code": "",
      "swift_account_number": "",
      "swift_bic": "",
      "transferwise_account_number": "",
      "transferwise_bank_code": ""
    },
    "amount_inquired": {
      "currency": "",
      "value": ""
    },
    "description": "",
    "invite_profile_name": "",
    "merchant_available": [
      {
        "available": false,
        "merchant_type": ""
      }
    ],
    "redirect_url": "",
    "status": "",
    "uuid": ""
  },
  "status": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "bunqme_tab_entry": {
    "alias": {
      "avatar": {
        "anchor_uuid": "",
        "image": [
          {
            "attachment_public_uuid": "",
            "content_type": "",
            "height": 0,
            "width": 0
          }
        ],
        "style": "",
        "uuid": ""
      },
      "bunq_me": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "country": "",
      "display_name": "",
      "iban": "",
      "is_light": false,
      "label_user": {
        "avatar": {},
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "merchant_category_code": "",
      "swift_account_number": "",
      "swift_bic": "",
      "transferwise_account_number": "",
      "transferwise_bank_code": ""
    },
    "amount_inquired": {
      "currency": "",
      "value": ""
    },
    "description": "",
    "invite_profile_name": "",
    "merchant_available": [
      {
        "available": false,
        "merchant_type": ""
      }
    ],
    "redirect_url": "",
    "status": "",
    "uuid": ""
  },
  "status": ""
}'
import http.client

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

payload = "{\n  \"bunqme_tab_entry\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"amount_inquired\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"description\": \"\",\n    \"invite_profile_name\": \"\",\n    \"merchant_available\": [\n      {\n        \"available\": false,\n        \"merchant_type\": \"\"\n      }\n    ],\n    \"redirect_url\": \"\",\n    \"status\": \"\",\n    \"uuid\": \"\"\n  },\n  \"status\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId", payload, headers)

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

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

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId"

payload = {
    "bunqme_tab_entry": {
        "alias": {
            "avatar": {
                "anchor_uuid": "",
                "image": [
                    {
                        "attachment_public_uuid": "",
                        "content_type": "",
                        "height": 0,
                        "width": 0
                    }
                ],
                "style": "",
                "uuid": ""
            },
            "bunq_me": {
                "name": "",
                "service": "",
                "type": "",
                "value": ""
            },
            "country": "",
            "display_name": "",
            "iban": "",
            "is_light": False,
            "label_user": {
                "avatar": {},
                "country": "",
                "display_name": "",
                "public_nick_name": "",
                "uuid": ""
            },
            "merchant_category_code": "",
            "swift_account_number": "",
            "swift_bic": "",
            "transferwise_account_number": "",
            "transferwise_bank_code": ""
        },
        "amount_inquired": {
            "currency": "",
            "value": ""
        },
        "description": "",
        "invite_profile_name": "",
        "merchant_available": [
            {
                "available": False,
                "merchant_type": ""
            }
        ],
        "redirect_url": "",
        "status": "",
        "uuid": ""
    },
    "status": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId"

payload <- "{\n  \"bunqme_tab_entry\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"amount_inquired\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"description\": \"\",\n    \"invite_profile_name\": \"\",\n    \"merchant_available\": [\n      {\n        \"available\": false,\n        \"merchant_type\": \"\"\n      }\n    ],\n    \"redirect_url\": \"\",\n    \"status\": \"\",\n    \"uuid\": \"\"\n  },\n  \"status\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId")

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

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"bunqme_tab_entry\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"amount_inquired\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"description\": \"\",\n    \"invite_profile_name\": \"\",\n    \"merchant_available\": [\n      {\n        \"available\": false,\n        \"merchant_type\": \"\"\n      }\n    ],\n    \"redirect_url\": \"\",\n    \"status\": \"\",\n    \"uuid\": \"\"\n  },\n  \"status\": \"\"\n}"

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

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

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"bunqme_tab_entry\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"amount_inquired\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"description\": \"\",\n    \"invite_profile_name\": \"\",\n    \"merchant_available\": [\n      {\n        \"available\": false,\n        \"merchant_type\": \"\"\n      }\n    ],\n    \"redirect_url\": \"\",\n    \"status\": \"\",\n    \"uuid\": \"\"\n  },\n  \"status\": \"\"\n}"
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId";

    let payload = json!({
        "bunqme_tab_entry": json!({
            "alias": json!({
                "avatar": json!({
                    "anchor_uuid": "",
                    "image": (
                        json!({
                            "attachment_public_uuid": "",
                            "content_type": "",
                            "height": 0,
                            "width": 0
                        })
                    ),
                    "style": "",
                    "uuid": ""
                }),
                "bunq_me": json!({
                    "name": "",
                    "service": "",
                    "type": "",
                    "value": ""
                }),
                "country": "",
                "display_name": "",
                "iban": "",
                "is_light": false,
                "label_user": json!({
                    "avatar": json!({}),
                    "country": "",
                    "display_name": "",
                    "public_nick_name": "",
                    "uuid": ""
                }),
                "merchant_category_code": "",
                "swift_account_number": "",
                "swift_bic": "",
                "transferwise_account_number": "",
                "transferwise_bank_code": ""
            }),
            "amount_inquired": json!({
                "currency": "",
                "value": ""
            }),
            "description": "",
            "invite_profile_name": "",
            "merchant_available": (
                json!({
                    "available": false,
                    "merchant_type": ""
                })
            ),
            "redirect_url": "",
            "status": "",
            "uuid": ""
        }),
        "status": ""
    });

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

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

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

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "bunqme_tab_entry": {
    "alias": {
      "avatar": {
        "anchor_uuid": "",
        "image": [
          {
            "attachment_public_uuid": "",
            "content_type": "",
            "height": 0,
            "width": 0
          }
        ],
        "style": "",
        "uuid": ""
      },
      "bunq_me": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "country": "",
      "display_name": "",
      "iban": "",
      "is_light": false,
      "label_user": {
        "avatar": {},
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "merchant_category_code": "",
      "swift_account_number": "",
      "swift_bic": "",
      "transferwise_account_number": "",
      "transferwise_bank_code": ""
    },
    "amount_inquired": {
      "currency": "",
      "value": ""
    },
    "description": "",
    "invite_profile_name": "",
    "merchant_available": [
      {
        "available": false,
        "merchant_type": ""
      }
    ],
    "redirect_url": "",
    "status": "",
    "uuid": ""
  },
  "status": ""
}'
echo '{
  "bunqme_tab_entry": {
    "alias": {
      "avatar": {
        "anchor_uuid": "",
        "image": [
          {
            "attachment_public_uuid": "",
            "content_type": "",
            "height": 0,
            "width": 0
          }
        ],
        "style": "",
        "uuid": ""
      },
      "bunq_me": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "country": "",
      "display_name": "",
      "iban": "",
      "is_light": false,
      "label_user": {
        "avatar": {},
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "merchant_category_code": "",
      "swift_account_number": "",
      "swift_bic": "",
      "transferwise_account_number": "",
      "transferwise_bank_code": ""
    },
    "amount_inquired": {
      "currency": "",
      "value": ""
    },
    "description": "",
    "invite_profile_name": "",
    "merchant_available": [
      {
        "available": false,
        "merchant_type": ""
      }
    ],
    "redirect_url": "",
    "status": "",
    "uuid": ""
  },
  "status": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "bunqme_tab_entry": {\n    "alias": {\n      "avatar": {\n        "anchor_uuid": "",\n        "image": [\n          {\n            "attachment_public_uuid": "",\n            "content_type": "",\n            "height": 0,\n            "width": 0\n          }\n        ],\n        "style": "",\n        "uuid": ""\n      },\n      "bunq_me": {\n        "name": "",\n        "service": "",\n        "type": "",\n        "value": ""\n      },\n      "country": "",\n      "display_name": "",\n      "iban": "",\n      "is_light": false,\n      "label_user": {\n        "avatar": {},\n        "country": "",\n        "display_name": "",\n        "public_nick_name": "",\n        "uuid": ""\n      },\n      "merchant_category_code": "",\n      "swift_account_number": "",\n      "swift_bic": "",\n      "transferwise_account_number": "",\n      "transferwise_bank_code": ""\n    },\n    "amount_inquired": {\n      "currency": "",\n      "value": ""\n    },\n    "description": "",\n    "invite_profile_name": "",\n    "merchant_available": [\n      {\n        "available": false,\n        "merchant_type": ""\n      }\n    ],\n    "redirect_url": "",\n    "status": "",\n    "uuid": ""\n  },\n  "status": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "bunqme_tab_entry": [
    "alias": [
      "avatar": [
        "anchor_uuid": "",
        "image": [
          [
            "attachment_public_uuid": "",
            "content_type": "",
            "height": 0,
            "width": 0
          ]
        ],
        "style": "",
        "uuid": ""
      ],
      "bunq_me": [
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      ],
      "country": "",
      "display_name": "",
      "iban": "",
      "is_light": false,
      "label_user": [
        "avatar": [],
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      ],
      "merchant_category_code": "",
      "swift_account_number": "",
      "swift_bic": "",
      "transferwise_account_number": "",
      "transferwise_bank_code": ""
    ],
    "amount_inquired": [
      "currency": "",
      "value": ""
    ],
    "description": "",
    "invite_profile_name": "",
    "merchant_available": [
      [
        "available": false,
        "merchant_type": ""
      ]
    ],
    "redirect_url": "",
    "status": "",
    "uuid": ""
  ],
  "status": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

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

dataTask.resume()
GET READ_BunqmeTabResultResponse_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab-result-response/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab-result-response/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab-result-response/:itemId" {:headers {:user-agent ""
                                                                                                                                          :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab-result-response/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab-result-response/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab-result-response/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab-result-response/:itemId"

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

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

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

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

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

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-tab-result-response/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab-result-response/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab-result-response/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab-result-response/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab-result-response/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab-result-response/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab-result-response/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab-result-response/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab-result-response/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab-result-response/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-tab-result-response/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab-result-response/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

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

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

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab-result-response/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab-result-response/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

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

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab-result-response/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

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

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab-result-response/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab-result-response/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab-result-response/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab-result-response/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab-result-response/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab-result-response/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab-result-response/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab-result-response/:itemId' -Method GET -Headers $headers
import http.client

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

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-tab-result-response/:itemId", headers=headers)

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

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

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab-result-response/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

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

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

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab-result-response/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab-result-response/:itemId")

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

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

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

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

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-tab-result-response/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab-result-response/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab-result-response/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab-result-response/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab-result-response/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-tab-result-response/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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

dataTask.resume()
POST CREATE_CallbackUrl_for_User_OauthClient
{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
oauth-clientID
BODY json

{
  "url": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"url\": \"\"\n}");

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

(client/post "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url" {:headers {:user-agent ""
                                                                                                             :x-bunq-client-authentication ""}
                                                                                                   :content-type :json
                                                                                                   :form-params {:url ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"url\": \"\"\n}"

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

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

func main() {

	url := "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url"

	payload := strings.NewReader("{\n  \"url\": \"\"\n}")

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

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

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

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

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

}
POST /baseUrl/user/:userID/oauth-client/:oauth-clientID/callback-url HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 15

{
  "url": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"url\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"url\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"url\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"url\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  url: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {url: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"url":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "url": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"url\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/oauth-client/:oauth-clientID/callback-url',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

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

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

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

req.write(JSON.stringify({url: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {url: ''},
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  url: ''
});

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}}/user/:userID/oauth-client/:oauth-clientID/callback-url',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {url: ''}
};

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

const url = '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"url":""}'
};

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

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"url": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

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

let uri = Uri.of_string "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"url\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'url' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url', [
  'body' => '{
  "url": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

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

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'url' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "url": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "url": ""
}'
import http.client

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

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

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/oauth-client/:oauth-clientID/callback-url", payload, headers)

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

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

url = "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url"

payload = { "url": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url"

payload <- "{\n  \"url\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url")

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

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"url\": \"\"\n}"

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

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

response = conn.post('/baseUrl/user/:userID/oauth-client/:oauth-clientID/callback-url') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"url\": \"\"\n}"
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url";

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

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "url": ""
}'
echo '{
  "url": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "url": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["url": ""] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

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

dataTask.resume()
DELETE DELETE_CallbackUrl_for_User_OauthClient
{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
oauth-clientID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/delete "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId" {:headers {:user-agent ""
                                                                                                                       :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId"

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

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

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

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

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

}
DELETE /baseUrl/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

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

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

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

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

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

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

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

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

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

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

const url = '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

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

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId"]
                                                       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}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId' -Method DELETE -Headers $headers
import http.client

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

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId", headers=headers)

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

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

url = "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

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

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

url <- "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId")

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

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

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

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

response = conn.delete('/baseUrl/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

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

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

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

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

dataTask.resume()
GET List_all_CallbackUrl_for_User_OauthClient
{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
oauth-clientID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url" {:headers {:user-agent ""
                                                                                                            :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url"

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

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

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

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

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

}
GET /baseUrl/user/:userID/oauth-client/:oauth-clientID/callback-url HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/oauth-client/:oauth-clientID/callback-url',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

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

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

const req = unirest('GET', '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

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

const url = '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

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

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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

let uri = Uri.of_string "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url' -Method GET -Headers $headers
import http.client

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

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/oauth-client/:oauth-clientID/callback-url", headers=headers)

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

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

url = "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

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

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

url <- "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url")

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

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

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

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

response = conn.get('/baseUrl/user/:userID/oauth-client/:oauth-clientID/callback-url') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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

dataTask.resume()
GET READ_CallbackUrl_for_User_OauthClient
{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
oauth-clientID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId" {:headers {:user-agent ""
                                                                                                                    :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId"

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

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

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

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

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

}
GET /baseUrl/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

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

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

const req = unirest('GET', '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

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

const url = '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

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

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

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

let uri = Uri.of_string "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId' -Method GET -Headers $headers
import http.client

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

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId", headers=headers)

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

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

url = "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

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

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

url <- "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId")

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

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

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

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

response = conn.get('/baseUrl/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

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

dataTask.resume()
PUT UPDATE_CallbackUrl_for_User_OauthClient
{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
oauth-clientID
itemId
BODY json

{
  "url": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"url\": \"\"\n}");

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

(client/put "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId" {:headers {:user-agent ""
                                                                                                                    :x-bunq-client-authentication ""}
                                                                                                          :content-type :json
                                                                                                          :form-params {:url ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"url\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"url\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"url\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId"

	payload := strings.NewReader("{\n  \"url\": \"\"\n}")

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

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

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

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

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

}
PUT /baseUrl/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 15

{
  "url": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"url\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"url\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"url\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"url\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  url: ''
});

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

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

xhr.open('PUT', '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {url: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"url":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "url": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"url\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

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

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

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

req.write(JSON.stringify({url: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {url: ''},
  json: true
};

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

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

const req = unirest('PUT', '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  url: ''
});

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}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {url: ''}
};

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

const url = '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"url":""}'
};

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

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"url": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

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

let uri = Uri.of_string "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"url\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'url' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId', [
  'body' => '{
  "url": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

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

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'url' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "url": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "url": ""
}'
import http.client

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

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

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId", payload, headers)

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

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

url = "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId"

payload = { "url": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

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

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

url <- "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId"

payload <- "{\n  \"url\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

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

url = URI("{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId")

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

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"url\": \"\"\n}"

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

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

response = conn.put('/baseUrl/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"url\": \"\"\n}"
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId";

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

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

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

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

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "url": ""
}'
echo '{
  "url": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "url": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["url": ""] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/oauth-client/:oauth-clientID/callback-url/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

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

dataTask.resume()
GET List_all_Card_for_User
{{baseUrl}}/user/:userID/card
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

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

(client/get "{{baseUrl}}/user/:userID/card" {:headers {:user-agent ""
                                                                       :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/card"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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

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

func main() {

	url := "{{baseUrl}}/user/:userID/card"

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

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

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

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

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

}
GET /baseUrl/user/:userID/card HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/card")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/card"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/card")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/card")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/user/:userID/card');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/card',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/card';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/card',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/card")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/card',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/card',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

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

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

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

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/card',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

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

const url = '{{baseUrl}}/user/:userID/card';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

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

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

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

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

let uri = Uri.of_string "{{baseUrl}}/user/:userID/card" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/card', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

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

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/card');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

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

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/card' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/card' -Method GET -Headers $headers
import http.client

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

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/card", headers=headers)

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

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

url = "{{baseUrl}}/user/:userID/card"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

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

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

url <- "{{baseUrl}}/user/:userID/card"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

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

url = URI("{{baseUrl}}/user/:userID/card")

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

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/card') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/card";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/card \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/card \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/card
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/card")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_Card_for_User
{{baseUrl}}/user/:userID/card/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/card/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/card/:itemId" {:headers {:user-agent ""
                                                                               :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/card/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/card/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/card/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/card/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/card/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/card/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/card/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/card/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/card/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/card/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/card/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/card/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/card/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/card/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/card/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/card/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/card/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/card/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/card/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/card/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/card/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/card/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/card/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/card/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/card/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/card/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/card/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/card/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/card/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/card/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/card/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/card/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/card/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/card/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/card/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/card/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/card/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_Card_for_User
{{baseUrl}}/user/:userID/card/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
BODY json

{
  "activation_code": "",
  "card_limit": {
    "currency": "",
    "value": ""
  },
  "card_limit_atm": {},
  "country_permission": [
    {
      "country": "",
      "expiry_time": "",
      "id": 0
    }
  ],
  "monetary_account_id_fallback": 0,
  "order_status": "",
  "pin_code": "",
  "pin_code_assignment": [
    {
      "monetary_account_id": 0,
      "pin_code": "",
      "routing_type": "",
      "type": ""
    }
  ],
  "primary_account_numbers": [
    {
      "description": "",
      "four_digit": "",
      "id": 0,
      "monetary_account_id": 0,
      "status": "",
      "uuid": ""
    }
  ],
  "status": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/card/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"activation_code\": \"\",\n  \"card_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"card_limit_atm\": {},\n  \"country_permission\": [\n    {\n      \"country\": \"\",\n      \"expiry_time\": \"\",\n      \"id\": 0\n    }\n  ],\n  \"monetary_account_id_fallback\": 0,\n  \"order_status\": \"\",\n  \"pin_code\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"primary_account_numbers\": [\n    {\n      \"description\": \"\",\n      \"four_digit\": \"\",\n      \"id\": 0,\n      \"monetary_account_id\": 0,\n      \"status\": \"\",\n      \"uuid\": \"\"\n    }\n  ],\n  \"status\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/card/:itemId" {:headers {:user-agent ""
                                                                               :x-bunq-client-authentication ""}
                                                                     :content-type :json
                                                                     :form-params {:activation_code ""
                                                                                   :card_limit {:currency ""
                                                                                                :value ""}
                                                                                   :card_limit_atm {}
                                                                                   :country_permission [{:country ""
                                                                                                         :expiry_time ""
                                                                                                         :id 0}]
                                                                                   :monetary_account_id_fallback 0
                                                                                   :order_status ""
                                                                                   :pin_code ""
                                                                                   :pin_code_assignment [{:monetary_account_id 0
                                                                                                          :pin_code ""
                                                                                                          :routing_type ""
                                                                                                          :type ""}]
                                                                                   :primary_account_numbers [{:description ""
                                                                                                              :four_digit ""
                                                                                                              :id 0
                                                                                                              :monetary_account_id 0
                                                                                                              :status ""
                                                                                                              :uuid ""}]
                                                                                   :status ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/card/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"activation_code\": \"\",\n  \"card_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"card_limit_atm\": {},\n  \"country_permission\": [\n    {\n      \"country\": \"\",\n      \"expiry_time\": \"\",\n      \"id\": 0\n    }\n  ],\n  \"monetary_account_id_fallback\": 0,\n  \"order_status\": \"\",\n  \"pin_code\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"primary_account_numbers\": [\n    {\n      \"description\": \"\",\n      \"four_digit\": \"\",\n      \"id\": 0,\n      \"monetary_account_id\": 0,\n      \"status\": \"\",\n      \"uuid\": \"\"\n    }\n  ],\n  \"status\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/card/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"activation_code\": \"\",\n  \"card_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"card_limit_atm\": {},\n  \"country_permission\": [\n    {\n      \"country\": \"\",\n      \"expiry_time\": \"\",\n      \"id\": 0\n    }\n  ],\n  \"monetary_account_id_fallback\": 0,\n  \"order_status\": \"\",\n  \"pin_code\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"primary_account_numbers\": [\n    {\n      \"description\": \"\",\n      \"four_digit\": \"\",\n      \"id\": 0,\n      \"monetary_account_id\": 0,\n      \"status\": \"\",\n      \"uuid\": \"\"\n    }\n  ],\n  \"status\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/card/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"activation_code\": \"\",\n  \"card_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"card_limit_atm\": {},\n  \"country_permission\": [\n    {\n      \"country\": \"\",\n      \"expiry_time\": \"\",\n      \"id\": 0\n    }\n  ],\n  \"monetary_account_id_fallback\": 0,\n  \"order_status\": \"\",\n  \"pin_code\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"primary_account_numbers\": [\n    {\n      \"description\": \"\",\n      \"four_digit\": \"\",\n      \"id\": 0,\n      \"monetary_account_id\": 0,\n      \"status\": \"\",\n      \"uuid\": \"\"\n    }\n  ],\n  \"status\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/card/:itemId"

	payload := strings.NewReader("{\n  \"activation_code\": \"\",\n  \"card_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"card_limit_atm\": {},\n  \"country_permission\": [\n    {\n      \"country\": \"\",\n      \"expiry_time\": \"\",\n      \"id\": 0\n    }\n  ],\n  \"monetary_account_id_fallback\": 0,\n  \"order_status\": \"\",\n  \"pin_code\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"primary_account_numbers\": [\n    {\n      \"description\": \"\",\n      \"four_digit\": \"\",\n      \"id\": 0,\n      \"monetary_account_id\": 0,\n      \"status\": \"\",\n      \"uuid\": \"\"\n    }\n  ],\n  \"status\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/card/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 628

{
  "activation_code": "",
  "card_limit": {
    "currency": "",
    "value": ""
  },
  "card_limit_atm": {},
  "country_permission": [
    {
      "country": "",
      "expiry_time": "",
      "id": 0
    }
  ],
  "monetary_account_id_fallback": 0,
  "order_status": "",
  "pin_code": "",
  "pin_code_assignment": [
    {
      "monetary_account_id": 0,
      "pin_code": "",
      "routing_type": "",
      "type": ""
    }
  ],
  "primary_account_numbers": [
    {
      "description": "",
      "four_digit": "",
      "id": 0,
      "monetary_account_id": 0,
      "status": "",
      "uuid": ""
    }
  ],
  "status": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/card/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"activation_code\": \"\",\n  \"card_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"card_limit_atm\": {},\n  \"country_permission\": [\n    {\n      \"country\": \"\",\n      \"expiry_time\": \"\",\n      \"id\": 0\n    }\n  ],\n  \"monetary_account_id_fallback\": 0,\n  \"order_status\": \"\",\n  \"pin_code\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"primary_account_numbers\": [\n    {\n      \"description\": \"\",\n      \"four_digit\": \"\",\n      \"id\": 0,\n      \"monetary_account_id\": 0,\n      \"status\": \"\",\n      \"uuid\": \"\"\n    }\n  ],\n  \"status\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/card/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"activation_code\": \"\",\n  \"card_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"card_limit_atm\": {},\n  \"country_permission\": [\n    {\n      \"country\": \"\",\n      \"expiry_time\": \"\",\n      \"id\": 0\n    }\n  ],\n  \"monetary_account_id_fallback\": 0,\n  \"order_status\": \"\",\n  \"pin_code\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"primary_account_numbers\": [\n    {\n      \"description\": \"\",\n      \"four_digit\": \"\",\n      \"id\": 0,\n      \"monetary_account_id\": 0,\n      \"status\": \"\",\n      \"uuid\": \"\"\n    }\n  ],\n  \"status\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"activation_code\": \"\",\n  \"card_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"card_limit_atm\": {},\n  \"country_permission\": [\n    {\n      \"country\": \"\",\n      \"expiry_time\": \"\",\n      \"id\": 0\n    }\n  ],\n  \"monetary_account_id_fallback\": 0,\n  \"order_status\": \"\",\n  \"pin_code\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"primary_account_numbers\": [\n    {\n      \"description\": \"\",\n      \"four_digit\": \"\",\n      \"id\": 0,\n      \"monetary_account_id\": 0,\n      \"status\": \"\",\n      \"uuid\": \"\"\n    }\n  ],\n  \"status\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/card/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/card/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"activation_code\": \"\",\n  \"card_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"card_limit_atm\": {},\n  \"country_permission\": [\n    {\n      \"country\": \"\",\n      \"expiry_time\": \"\",\n      \"id\": 0\n    }\n  ],\n  \"monetary_account_id_fallback\": 0,\n  \"order_status\": \"\",\n  \"pin_code\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"primary_account_numbers\": [\n    {\n      \"description\": \"\",\n      \"four_digit\": \"\",\n      \"id\": 0,\n      \"monetary_account_id\": 0,\n      \"status\": \"\",\n      \"uuid\": \"\"\n    }\n  ],\n  \"status\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  activation_code: '',
  card_limit: {
    currency: '',
    value: ''
  },
  card_limit_atm: {},
  country_permission: [
    {
      country: '',
      expiry_time: '',
      id: 0
    }
  ],
  monetary_account_id_fallback: 0,
  order_status: '',
  pin_code: '',
  pin_code_assignment: [
    {
      monetary_account_id: 0,
      pin_code: '',
      routing_type: '',
      type: ''
    }
  ],
  primary_account_numbers: [
    {
      description: '',
      four_digit: '',
      id: 0,
      monetary_account_id: 0,
      status: '',
      uuid: ''
    }
  ],
  status: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/card/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/card/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    activation_code: '',
    card_limit: {currency: '', value: ''},
    card_limit_atm: {},
    country_permission: [{country: '', expiry_time: '', id: 0}],
    monetary_account_id_fallback: 0,
    order_status: '',
    pin_code: '',
    pin_code_assignment: [{monetary_account_id: 0, pin_code: '', routing_type: '', type: ''}],
    primary_account_numbers: [
      {
        description: '',
        four_digit: '',
        id: 0,
        monetary_account_id: 0,
        status: '',
        uuid: ''
      }
    ],
    status: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/card/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"activation_code":"","card_limit":{"currency":"","value":""},"card_limit_atm":{},"country_permission":[{"country":"","expiry_time":"","id":0}],"monetary_account_id_fallback":0,"order_status":"","pin_code":"","pin_code_assignment":[{"monetary_account_id":0,"pin_code":"","routing_type":"","type":""}],"primary_account_numbers":[{"description":"","four_digit":"","id":0,"monetary_account_id":0,"status":"","uuid":""}],"status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/card/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "activation_code": "",\n  "card_limit": {\n    "currency": "",\n    "value": ""\n  },\n  "card_limit_atm": {},\n  "country_permission": [\n    {\n      "country": "",\n      "expiry_time": "",\n      "id": 0\n    }\n  ],\n  "monetary_account_id_fallback": 0,\n  "order_status": "",\n  "pin_code": "",\n  "pin_code_assignment": [\n    {\n      "monetary_account_id": 0,\n      "pin_code": "",\n      "routing_type": "",\n      "type": ""\n    }\n  ],\n  "primary_account_numbers": [\n    {\n      "description": "",\n      "four_digit": "",\n      "id": 0,\n      "monetary_account_id": 0,\n      "status": "",\n      "uuid": ""\n    }\n  ],\n  "status": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"activation_code\": \"\",\n  \"card_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"card_limit_atm\": {},\n  \"country_permission\": [\n    {\n      \"country\": \"\",\n      \"expiry_time\": \"\",\n      \"id\": 0\n    }\n  ],\n  \"monetary_account_id_fallback\": 0,\n  \"order_status\": \"\",\n  \"pin_code\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"primary_account_numbers\": [\n    {\n      \"description\": \"\",\n      \"four_digit\": \"\",\n      \"id\": 0,\n      \"monetary_account_id\": 0,\n      \"status\": \"\",\n      \"uuid\": \"\"\n    }\n  ],\n  \"status\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/card/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/card/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  activation_code: '',
  card_limit: {currency: '', value: ''},
  card_limit_atm: {},
  country_permission: [{country: '', expiry_time: '', id: 0}],
  monetary_account_id_fallback: 0,
  order_status: '',
  pin_code: '',
  pin_code_assignment: [{monetary_account_id: 0, pin_code: '', routing_type: '', type: ''}],
  primary_account_numbers: [
    {
      description: '',
      four_digit: '',
      id: 0,
      monetary_account_id: 0,
      status: '',
      uuid: ''
    }
  ],
  status: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/card/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    activation_code: '',
    card_limit: {currency: '', value: ''},
    card_limit_atm: {},
    country_permission: [{country: '', expiry_time: '', id: 0}],
    monetary_account_id_fallback: 0,
    order_status: '',
    pin_code: '',
    pin_code_assignment: [{monetary_account_id: 0, pin_code: '', routing_type: '', type: ''}],
    primary_account_numbers: [
      {
        description: '',
        four_digit: '',
        id: 0,
        monetary_account_id: 0,
        status: '',
        uuid: ''
      }
    ],
    status: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/card/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  activation_code: '',
  card_limit: {
    currency: '',
    value: ''
  },
  card_limit_atm: {},
  country_permission: [
    {
      country: '',
      expiry_time: '',
      id: 0
    }
  ],
  monetary_account_id_fallback: 0,
  order_status: '',
  pin_code: '',
  pin_code_assignment: [
    {
      monetary_account_id: 0,
      pin_code: '',
      routing_type: '',
      type: ''
    }
  ],
  primary_account_numbers: [
    {
      description: '',
      four_digit: '',
      id: 0,
      monetary_account_id: 0,
      status: '',
      uuid: ''
    }
  ],
  status: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/card/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    activation_code: '',
    card_limit: {currency: '', value: ''},
    card_limit_atm: {},
    country_permission: [{country: '', expiry_time: '', id: 0}],
    monetary_account_id_fallback: 0,
    order_status: '',
    pin_code: '',
    pin_code_assignment: [{monetary_account_id: 0, pin_code: '', routing_type: '', type: ''}],
    primary_account_numbers: [
      {
        description: '',
        four_digit: '',
        id: 0,
        monetary_account_id: 0,
        status: '',
        uuid: ''
      }
    ],
    status: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/card/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"activation_code":"","card_limit":{"currency":"","value":""},"card_limit_atm":{},"country_permission":[{"country":"","expiry_time":"","id":0}],"monetary_account_id_fallback":0,"order_status":"","pin_code":"","pin_code_assignment":[{"monetary_account_id":0,"pin_code":"","routing_type":"","type":""}],"primary_account_numbers":[{"description":"","four_digit":"","id":0,"monetary_account_id":0,"status":"","uuid":""}],"status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"activation_code": @"",
                              @"card_limit": @{ @"currency": @"", @"value": @"" },
                              @"card_limit_atm": @{  },
                              @"country_permission": @[ @{ @"country": @"", @"expiry_time": @"", @"id": @0 } ],
                              @"monetary_account_id_fallback": @0,
                              @"order_status": @"",
                              @"pin_code": @"",
                              @"pin_code_assignment": @[ @{ @"monetary_account_id": @0, @"pin_code": @"", @"routing_type": @"", @"type": @"" } ],
                              @"primary_account_numbers": @[ @{ @"description": @"", @"four_digit": @"", @"id": @0, @"monetary_account_id": @0, @"status": @"", @"uuid": @"" } ],
                              @"status": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/card/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/card/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"activation_code\": \"\",\n  \"card_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"card_limit_atm\": {},\n  \"country_permission\": [\n    {\n      \"country\": \"\",\n      \"expiry_time\": \"\",\n      \"id\": 0\n    }\n  ],\n  \"monetary_account_id_fallback\": 0,\n  \"order_status\": \"\",\n  \"pin_code\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"primary_account_numbers\": [\n    {\n      \"description\": \"\",\n      \"four_digit\": \"\",\n      \"id\": 0,\n      \"monetary_account_id\": 0,\n      \"status\": \"\",\n      \"uuid\": \"\"\n    }\n  ],\n  \"status\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/card/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'activation_code' => '',
    'card_limit' => [
        'currency' => '',
        'value' => ''
    ],
    'card_limit_atm' => [
        
    ],
    'country_permission' => [
        [
                'country' => '',
                'expiry_time' => '',
                'id' => 0
        ]
    ],
    'monetary_account_id_fallback' => 0,
    'order_status' => '',
    'pin_code' => '',
    'pin_code_assignment' => [
        [
                'monetary_account_id' => 0,
                'pin_code' => '',
                'routing_type' => '',
                'type' => ''
        ]
    ],
    'primary_account_numbers' => [
        [
                'description' => '',
                'four_digit' => '',
                'id' => 0,
                'monetary_account_id' => 0,
                'status' => '',
                'uuid' => ''
        ]
    ],
    'status' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/card/:itemId', [
  'body' => '{
  "activation_code": "",
  "card_limit": {
    "currency": "",
    "value": ""
  },
  "card_limit_atm": {},
  "country_permission": [
    {
      "country": "",
      "expiry_time": "",
      "id": 0
    }
  ],
  "monetary_account_id_fallback": 0,
  "order_status": "",
  "pin_code": "",
  "pin_code_assignment": [
    {
      "monetary_account_id": 0,
      "pin_code": "",
      "routing_type": "",
      "type": ""
    }
  ],
  "primary_account_numbers": [
    {
      "description": "",
      "four_digit": "",
      "id": 0,
      "monetary_account_id": 0,
      "status": "",
      "uuid": ""
    }
  ],
  "status": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/card/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'activation_code' => '',
  'card_limit' => [
    'currency' => '',
    'value' => ''
  ],
  'card_limit_atm' => [
    
  ],
  'country_permission' => [
    [
        'country' => '',
        'expiry_time' => '',
        'id' => 0
    ]
  ],
  'monetary_account_id_fallback' => 0,
  'order_status' => '',
  'pin_code' => '',
  'pin_code_assignment' => [
    [
        'monetary_account_id' => 0,
        'pin_code' => '',
        'routing_type' => '',
        'type' => ''
    ]
  ],
  'primary_account_numbers' => [
    [
        'description' => '',
        'four_digit' => '',
        'id' => 0,
        'monetary_account_id' => 0,
        'status' => '',
        'uuid' => ''
    ]
  ],
  'status' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'activation_code' => '',
  'card_limit' => [
    'currency' => '',
    'value' => ''
  ],
  'card_limit_atm' => [
    
  ],
  'country_permission' => [
    [
        'country' => '',
        'expiry_time' => '',
        'id' => 0
    ]
  ],
  'monetary_account_id_fallback' => 0,
  'order_status' => '',
  'pin_code' => '',
  'pin_code_assignment' => [
    [
        'monetary_account_id' => 0,
        'pin_code' => '',
        'routing_type' => '',
        'type' => ''
    ]
  ],
  'primary_account_numbers' => [
    [
        'description' => '',
        'four_digit' => '',
        'id' => 0,
        'monetary_account_id' => 0,
        'status' => '',
        'uuid' => ''
    ]
  ],
  'status' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/card/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/card/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "activation_code": "",
  "card_limit": {
    "currency": "",
    "value": ""
  },
  "card_limit_atm": {},
  "country_permission": [
    {
      "country": "",
      "expiry_time": "",
      "id": 0
    }
  ],
  "monetary_account_id_fallback": 0,
  "order_status": "",
  "pin_code": "",
  "pin_code_assignment": [
    {
      "monetary_account_id": 0,
      "pin_code": "",
      "routing_type": "",
      "type": ""
    }
  ],
  "primary_account_numbers": [
    {
      "description": "",
      "four_digit": "",
      "id": 0,
      "monetary_account_id": 0,
      "status": "",
      "uuid": ""
    }
  ],
  "status": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/card/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "activation_code": "",
  "card_limit": {
    "currency": "",
    "value": ""
  },
  "card_limit_atm": {},
  "country_permission": [
    {
      "country": "",
      "expiry_time": "",
      "id": 0
    }
  ],
  "monetary_account_id_fallback": 0,
  "order_status": "",
  "pin_code": "",
  "pin_code_assignment": [
    {
      "monetary_account_id": 0,
      "pin_code": "",
      "routing_type": "",
      "type": ""
    }
  ],
  "primary_account_numbers": [
    {
      "description": "",
      "four_digit": "",
      "id": 0,
      "monetary_account_id": 0,
      "status": "",
      "uuid": ""
    }
  ],
  "status": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"activation_code\": \"\",\n  \"card_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"card_limit_atm\": {},\n  \"country_permission\": [\n    {\n      \"country\": \"\",\n      \"expiry_time\": \"\",\n      \"id\": 0\n    }\n  ],\n  \"monetary_account_id_fallback\": 0,\n  \"order_status\": \"\",\n  \"pin_code\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"primary_account_numbers\": [\n    {\n      \"description\": \"\",\n      \"four_digit\": \"\",\n      \"id\": 0,\n      \"monetary_account_id\": 0,\n      \"status\": \"\",\n      \"uuid\": \"\"\n    }\n  ],\n  \"status\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/card/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/card/:itemId"

payload = {
    "activation_code": "",
    "card_limit": {
        "currency": "",
        "value": ""
    },
    "card_limit_atm": {},
    "country_permission": [
        {
            "country": "",
            "expiry_time": "",
            "id": 0
        }
    ],
    "monetary_account_id_fallback": 0,
    "order_status": "",
    "pin_code": "",
    "pin_code_assignment": [
        {
            "monetary_account_id": 0,
            "pin_code": "",
            "routing_type": "",
            "type": ""
        }
    ],
    "primary_account_numbers": [
        {
            "description": "",
            "four_digit": "",
            "id": 0,
            "monetary_account_id": 0,
            "status": "",
            "uuid": ""
        }
    ],
    "status": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/card/:itemId"

payload <- "{\n  \"activation_code\": \"\",\n  \"card_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"card_limit_atm\": {},\n  \"country_permission\": [\n    {\n      \"country\": \"\",\n      \"expiry_time\": \"\",\n      \"id\": 0\n    }\n  ],\n  \"monetary_account_id_fallback\": 0,\n  \"order_status\": \"\",\n  \"pin_code\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"primary_account_numbers\": [\n    {\n      \"description\": \"\",\n      \"four_digit\": \"\",\n      \"id\": 0,\n      \"monetary_account_id\": 0,\n      \"status\": \"\",\n      \"uuid\": \"\"\n    }\n  ],\n  \"status\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/card/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"activation_code\": \"\",\n  \"card_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"card_limit_atm\": {},\n  \"country_permission\": [\n    {\n      \"country\": \"\",\n      \"expiry_time\": \"\",\n      \"id\": 0\n    }\n  ],\n  \"monetary_account_id_fallback\": 0,\n  \"order_status\": \"\",\n  \"pin_code\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"primary_account_numbers\": [\n    {\n      \"description\": \"\",\n      \"four_digit\": \"\",\n      \"id\": 0,\n      \"monetary_account_id\": 0,\n      \"status\": \"\",\n      \"uuid\": \"\"\n    }\n  ],\n  \"status\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/card/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"activation_code\": \"\",\n  \"card_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"card_limit_atm\": {},\n  \"country_permission\": [\n    {\n      \"country\": \"\",\n      \"expiry_time\": \"\",\n      \"id\": 0\n    }\n  ],\n  \"monetary_account_id_fallback\": 0,\n  \"order_status\": \"\",\n  \"pin_code\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"primary_account_numbers\": [\n    {\n      \"description\": \"\",\n      \"four_digit\": \"\",\n      \"id\": 0,\n      \"monetary_account_id\": 0,\n      \"status\": \"\",\n      \"uuid\": \"\"\n    }\n  ],\n  \"status\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/card/:itemId";

    let payload = json!({
        "activation_code": "",
        "card_limit": json!({
            "currency": "",
            "value": ""
        }),
        "card_limit_atm": json!({}),
        "country_permission": (
            json!({
                "country": "",
                "expiry_time": "",
                "id": 0
            })
        ),
        "monetary_account_id_fallback": 0,
        "order_status": "",
        "pin_code": "",
        "pin_code_assignment": (
            json!({
                "monetary_account_id": 0,
                "pin_code": "",
                "routing_type": "",
                "type": ""
            })
        ),
        "primary_account_numbers": (
            json!({
                "description": "",
                "four_digit": "",
                "id": 0,
                "monetary_account_id": 0,
                "status": "",
                "uuid": ""
            })
        ),
        "status": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/card/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "activation_code": "",
  "card_limit": {
    "currency": "",
    "value": ""
  },
  "card_limit_atm": {},
  "country_permission": [
    {
      "country": "",
      "expiry_time": "",
      "id": 0
    }
  ],
  "monetary_account_id_fallback": 0,
  "order_status": "",
  "pin_code": "",
  "pin_code_assignment": [
    {
      "monetary_account_id": 0,
      "pin_code": "",
      "routing_type": "",
      "type": ""
    }
  ],
  "primary_account_numbers": [
    {
      "description": "",
      "four_digit": "",
      "id": 0,
      "monetary_account_id": 0,
      "status": "",
      "uuid": ""
    }
  ],
  "status": ""
}'
echo '{
  "activation_code": "",
  "card_limit": {
    "currency": "",
    "value": ""
  },
  "card_limit_atm": {},
  "country_permission": [
    {
      "country": "",
      "expiry_time": "",
      "id": 0
    }
  ],
  "monetary_account_id_fallback": 0,
  "order_status": "",
  "pin_code": "",
  "pin_code_assignment": [
    {
      "monetary_account_id": 0,
      "pin_code": "",
      "routing_type": "",
      "type": ""
    }
  ],
  "primary_account_numbers": [
    {
      "description": "",
      "four_digit": "",
      "id": 0,
      "monetary_account_id": 0,
      "status": "",
      "uuid": ""
    }
  ],
  "status": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/card/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "activation_code": "",\n  "card_limit": {\n    "currency": "",\n    "value": ""\n  },\n  "card_limit_atm": {},\n  "country_permission": [\n    {\n      "country": "",\n      "expiry_time": "",\n      "id": 0\n    }\n  ],\n  "monetary_account_id_fallback": 0,\n  "order_status": "",\n  "pin_code": "",\n  "pin_code_assignment": [\n    {\n      "monetary_account_id": 0,\n      "pin_code": "",\n      "routing_type": "",\n      "type": ""\n    }\n  ],\n  "primary_account_numbers": [\n    {\n      "description": "",\n      "four_digit": "",\n      "id": 0,\n      "monetary_account_id": 0,\n      "status": "",\n      "uuid": ""\n    }\n  ],\n  "status": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/card/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "activation_code": "",
  "card_limit": [
    "currency": "",
    "value": ""
  ],
  "card_limit_atm": [],
  "country_permission": [
    [
      "country": "",
      "expiry_time": "",
      "id": 0
    ]
  ],
  "monetary_account_id_fallback": 0,
  "order_status": "",
  "pin_code": "",
  "pin_code_assignment": [
    [
      "monetary_account_id": 0,
      "pin_code": "",
      "routing_type": "",
      "type": ""
    ]
  ],
  "primary_account_numbers": [
    [
      "description": "",
      "four_digit": "",
      "id": 0,
      "monetary_account_id": 0,
      "status": "",
      "uuid": ""
    ]
  ],
  "status": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/card/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_CardBatch_for_User
{{baseUrl}}/user/:userID/card-batch
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
BODY json

{
  "cards": [
    {
      "card_limit": {
        "currency": "",
        "value": ""
      },
      "card_limit_atm": {},
      "country_permission": [
        {
          "country": "",
          "expiry_time": "",
          "id": 0
        }
      ],
      "id": 0,
      "monetary_account_id_fallback": 0,
      "status": ""
    }
  ]
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/card-batch");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"cards\": [\n    {\n      \"card_limit\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"card_limit_atm\": {},\n      \"country_permission\": [\n        {\n          \"country\": \"\",\n          \"expiry_time\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"id\": 0,\n      \"monetary_account_id_fallback\": 0,\n      \"status\": \"\"\n    }\n  ]\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/card-batch" {:headers {:user-agent ""
                                                                              :x-bunq-client-authentication ""}
                                                                    :content-type :json
                                                                    :form-params {:cards [{:card_limit {:currency ""
                                                                                                        :value ""}
                                                                                           :card_limit_atm {}
                                                                                           :country_permission [{:country ""
                                                                                                                 :expiry_time ""
                                                                                                                 :id 0}]
                                                                                           :id 0
                                                                                           :monetary_account_id_fallback 0
                                                                                           :status ""}]}})
require "http/client"

url = "{{baseUrl}}/user/:userID/card-batch"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"cards\": [\n    {\n      \"card_limit\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"card_limit_atm\": {},\n      \"country_permission\": [\n        {\n          \"country\": \"\",\n          \"expiry_time\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"id\": 0,\n      \"monetary_account_id_fallback\": 0,\n      \"status\": \"\"\n    }\n  ]\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/card-batch"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"cards\": [\n    {\n      \"card_limit\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"card_limit_atm\": {},\n      \"country_permission\": [\n        {\n          \"country\": \"\",\n          \"expiry_time\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"id\": 0,\n      \"monetary_account_id_fallback\": 0,\n      \"status\": \"\"\n    }\n  ]\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/card-batch");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"cards\": [\n    {\n      \"card_limit\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"card_limit_atm\": {},\n      \"country_permission\": [\n        {\n          \"country\": \"\",\n          \"expiry_time\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"id\": 0,\n      \"monetary_account_id_fallback\": 0,\n      \"status\": \"\"\n    }\n  ]\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/card-batch"

	payload := strings.NewReader("{\n  \"cards\": [\n    {\n      \"card_limit\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"card_limit_atm\": {},\n      \"country_permission\": [\n        {\n          \"country\": \"\",\n          \"expiry_time\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"id\": 0,\n      \"monetary_account_id_fallback\": 0,\n      \"status\": \"\"\n    }\n  ]\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/card-batch HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 341

{
  "cards": [
    {
      "card_limit": {
        "currency": "",
        "value": ""
      },
      "card_limit_atm": {},
      "country_permission": [
        {
          "country": "",
          "expiry_time": "",
          "id": 0
        }
      ],
      "id": 0,
      "monetary_account_id_fallback": 0,
      "status": ""
    }
  ]
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/card-batch")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"cards\": [\n    {\n      \"card_limit\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"card_limit_atm\": {},\n      \"country_permission\": [\n        {\n          \"country\": \"\",\n          \"expiry_time\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"id\": 0,\n      \"monetary_account_id_fallback\": 0,\n      \"status\": \"\"\n    }\n  ]\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/card-batch"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"cards\": [\n    {\n      \"card_limit\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"card_limit_atm\": {},\n      \"country_permission\": [\n        {\n          \"country\": \"\",\n          \"expiry_time\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"id\": 0,\n      \"monetary_account_id_fallback\": 0,\n      \"status\": \"\"\n    }\n  ]\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"cards\": [\n    {\n      \"card_limit\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"card_limit_atm\": {},\n      \"country_permission\": [\n        {\n          \"country\": \"\",\n          \"expiry_time\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"id\": 0,\n      \"monetary_account_id_fallback\": 0,\n      \"status\": \"\"\n    }\n  ]\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/card-batch")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/card-batch")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"cards\": [\n    {\n      \"card_limit\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"card_limit_atm\": {},\n      \"country_permission\": [\n        {\n          \"country\": \"\",\n          \"expiry_time\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"id\": 0,\n      \"monetary_account_id_fallback\": 0,\n      \"status\": \"\"\n    }\n  ]\n}")
  .asString();
const data = JSON.stringify({
  cards: [
    {
      card_limit: {
        currency: '',
        value: ''
      },
      card_limit_atm: {},
      country_permission: [
        {
          country: '',
          expiry_time: '',
          id: 0
        }
      ],
      id: 0,
      monetary_account_id_fallback: 0,
      status: ''
    }
  ]
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/card-batch');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/card-batch',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    cards: [
      {
        card_limit: {currency: '', value: ''},
        card_limit_atm: {},
        country_permission: [{country: '', expiry_time: '', id: 0}],
        id: 0,
        monetary_account_id_fallback: 0,
        status: ''
      }
    ]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/card-batch';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"cards":[{"card_limit":{"currency":"","value":""},"card_limit_atm":{},"country_permission":[{"country":"","expiry_time":"","id":0}],"id":0,"monetary_account_id_fallback":0,"status":""}]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/card-batch',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "cards": [\n    {\n      "card_limit": {\n        "currency": "",\n        "value": ""\n      },\n      "card_limit_atm": {},\n      "country_permission": [\n        {\n          "country": "",\n          "expiry_time": "",\n          "id": 0\n        }\n      ],\n      "id": 0,\n      "monetary_account_id_fallback": 0,\n      "status": ""\n    }\n  ]\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"cards\": [\n    {\n      \"card_limit\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"card_limit_atm\": {},\n      \"country_permission\": [\n        {\n          \"country\": \"\",\n          \"expiry_time\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"id\": 0,\n      \"monetary_account_id_fallback\": 0,\n      \"status\": \"\"\n    }\n  ]\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/card-batch")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/card-batch',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  cards: [
    {
      card_limit: {currency: '', value: ''},
      card_limit_atm: {},
      country_permission: [{country: '', expiry_time: '', id: 0}],
      id: 0,
      monetary_account_id_fallback: 0,
      status: ''
    }
  ]
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/card-batch',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    cards: [
      {
        card_limit: {currency: '', value: ''},
        card_limit_atm: {},
        country_permission: [{country: '', expiry_time: '', id: 0}],
        id: 0,
        monetary_account_id_fallback: 0,
        status: ''
      }
    ]
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/card-batch');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  cards: [
    {
      card_limit: {
        currency: '',
        value: ''
      },
      card_limit_atm: {},
      country_permission: [
        {
          country: '',
          expiry_time: '',
          id: 0
        }
      ],
      id: 0,
      monetary_account_id_fallback: 0,
      status: ''
    }
  ]
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/card-batch',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    cards: [
      {
        card_limit: {currency: '', value: ''},
        card_limit_atm: {},
        country_permission: [{country: '', expiry_time: '', id: 0}],
        id: 0,
        monetary_account_id_fallback: 0,
        status: ''
      }
    ]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/card-batch';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"cards":[{"card_limit":{"currency":"","value":""},"card_limit_atm":{},"country_permission":[{"country":"","expiry_time":"","id":0}],"id":0,"monetary_account_id_fallback":0,"status":""}]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"cards": @[ @{ @"card_limit": @{ @"currency": @"", @"value": @"" }, @"card_limit_atm": @{  }, @"country_permission": @[ @{ @"country": @"", @"expiry_time": @"", @"id": @0 } ], @"id": @0, @"monetary_account_id_fallback": @0, @"status": @"" } ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/card-batch"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/card-batch" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"cards\": [\n    {\n      \"card_limit\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"card_limit_atm\": {},\n      \"country_permission\": [\n        {\n          \"country\": \"\",\n          \"expiry_time\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"id\": 0,\n      \"monetary_account_id_fallback\": 0,\n      \"status\": \"\"\n    }\n  ]\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/card-batch",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'cards' => [
        [
                'card_limit' => [
                                'currency' => '',
                                'value' => ''
                ],
                'card_limit_atm' => [
                                
                ],
                'country_permission' => [
                                [
                                                                'country' => '',
                                                                'expiry_time' => '',
                                                                'id' => 0
                                ]
                ],
                'id' => 0,
                'monetary_account_id_fallback' => 0,
                'status' => ''
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/card-batch', [
  'body' => '{
  "cards": [
    {
      "card_limit": {
        "currency": "",
        "value": ""
      },
      "card_limit_atm": {},
      "country_permission": [
        {
          "country": "",
          "expiry_time": "",
          "id": 0
        }
      ],
      "id": 0,
      "monetary_account_id_fallback": 0,
      "status": ""
    }
  ]
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/card-batch');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'cards' => [
    [
        'card_limit' => [
                'currency' => '',
                'value' => ''
        ],
        'card_limit_atm' => [
                
        ],
        'country_permission' => [
                [
                                'country' => '',
                                'expiry_time' => '',
                                'id' => 0
                ]
        ],
        'id' => 0,
        'monetary_account_id_fallback' => 0,
        'status' => ''
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'cards' => [
    [
        'card_limit' => [
                'currency' => '',
                'value' => ''
        ],
        'card_limit_atm' => [
                
        ],
        'country_permission' => [
                [
                                'country' => '',
                                'expiry_time' => '',
                                'id' => 0
                ]
        ],
        'id' => 0,
        'monetary_account_id_fallback' => 0,
        'status' => ''
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/card-batch');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/card-batch' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "cards": [
    {
      "card_limit": {
        "currency": "",
        "value": ""
      },
      "card_limit_atm": {},
      "country_permission": [
        {
          "country": "",
          "expiry_time": "",
          "id": 0
        }
      ],
      "id": 0,
      "monetary_account_id_fallback": 0,
      "status": ""
    }
  ]
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/card-batch' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "cards": [
    {
      "card_limit": {
        "currency": "",
        "value": ""
      },
      "card_limit_atm": {},
      "country_permission": [
        {
          "country": "",
          "expiry_time": "",
          "id": 0
        }
      ],
      "id": 0,
      "monetary_account_id_fallback": 0,
      "status": ""
    }
  ]
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"cards\": [\n    {\n      \"card_limit\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"card_limit_atm\": {},\n      \"country_permission\": [\n        {\n          \"country\": \"\",\n          \"expiry_time\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"id\": 0,\n      \"monetary_account_id_fallback\": 0,\n      \"status\": \"\"\n    }\n  ]\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/card-batch", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/card-batch"

payload = { "cards": [
        {
            "card_limit": {
                "currency": "",
                "value": ""
            },
            "card_limit_atm": {},
            "country_permission": [
                {
                    "country": "",
                    "expiry_time": "",
                    "id": 0
                }
            ],
            "id": 0,
            "monetary_account_id_fallback": 0,
            "status": ""
        }
    ] }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/card-batch"

payload <- "{\n  \"cards\": [\n    {\n      \"card_limit\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"card_limit_atm\": {},\n      \"country_permission\": [\n        {\n          \"country\": \"\",\n          \"expiry_time\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"id\": 0,\n      \"monetary_account_id_fallback\": 0,\n      \"status\": \"\"\n    }\n  ]\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/card-batch")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"cards\": [\n    {\n      \"card_limit\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"card_limit_atm\": {},\n      \"country_permission\": [\n        {\n          \"country\": \"\",\n          \"expiry_time\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"id\": 0,\n      \"monetary_account_id_fallback\": 0,\n      \"status\": \"\"\n    }\n  ]\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/card-batch') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"cards\": [\n    {\n      \"card_limit\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"card_limit_atm\": {},\n      \"country_permission\": [\n        {\n          \"country\": \"\",\n          \"expiry_time\": \"\",\n          \"id\": 0\n        }\n      ],\n      \"id\": 0,\n      \"monetary_account_id_fallback\": 0,\n      \"status\": \"\"\n    }\n  ]\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/card-batch";

    let payload = json!({"cards": (
            json!({
                "card_limit": json!({
                    "currency": "",
                    "value": ""
                }),
                "card_limit_atm": json!({}),
                "country_permission": (
                    json!({
                        "country": "",
                        "expiry_time": "",
                        "id": 0
                    })
                ),
                "id": 0,
                "monetary_account_id_fallback": 0,
                "status": ""
            })
        )});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/card-batch \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "cards": [
    {
      "card_limit": {
        "currency": "",
        "value": ""
      },
      "card_limit_atm": {},
      "country_permission": [
        {
          "country": "",
          "expiry_time": "",
          "id": 0
        }
      ],
      "id": 0,
      "monetary_account_id_fallback": 0,
      "status": ""
    }
  ]
}'
echo '{
  "cards": [
    {
      "card_limit": {
        "currency": "",
        "value": ""
      },
      "card_limit_atm": {},
      "country_permission": [
        {
          "country": "",
          "expiry_time": "",
          "id": 0
        }
      ],
      "id": 0,
      "monetary_account_id_fallback": 0,
      "status": ""
    }
  ]
}' |  \
  http POST {{baseUrl}}/user/:userID/card-batch \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "cards": [\n    {\n      "card_limit": {\n        "currency": "",\n        "value": ""\n      },\n      "card_limit_atm": {},\n      "country_permission": [\n        {\n          "country": "",\n          "expiry_time": "",\n          "id": 0\n        }\n      ],\n      "id": 0,\n      "monetary_account_id_fallback": 0,\n      "status": ""\n    }\n  ]\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/card-batch
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["cards": [
    [
      "card_limit": [
        "currency": "",
        "value": ""
      ],
      "card_limit_atm": [],
      "country_permission": [
        [
          "country": "",
          "expiry_time": "",
          "id": 0
        ]
      ],
      "id": 0,
      "monetary_account_id_fallback": 0,
      "status": ""
    ]
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/card-batch")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_CardBatchReplace_for_User
{{baseUrl}}/user/:userID/card-batch-replace
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
BODY json

{
  "cards": [
    {
      "id": 0,
      "name_on_card": "",
      "pin_code_assignment": [
        {
          "monetary_account_id": 0,
          "pin_code": "",
          "routing_type": "",
          "type": ""
        }
      ],
      "second_line": ""
    }
  ]
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/card-batch-replace");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"cards\": [\n    {\n      \"id\": 0,\n      \"name_on_card\": \"\",\n      \"pin_code_assignment\": [\n        {\n          \"monetary_account_id\": 0,\n          \"pin_code\": \"\",\n          \"routing_type\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"second_line\": \"\"\n    }\n  ]\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/card-batch-replace" {:headers {:user-agent ""
                                                                                      :x-bunq-client-authentication ""}
                                                                            :content-type :json
                                                                            :form-params {:cards [{:id 0
                                                                                                   :name_on_card ""
                                                                                                   :pin_code_assignment [{:monetary_account_id 0
                                                                                                                          :pin_code ""
                                                                                                                          :routing_type ""
                                                                                                                          :type ""}]
                                                                                                   :second_line ""}]}})
require "http/client"

url = "{{baseUrl}}/user/:userID/card-batch-replace"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"cards\": [\n    {\n      \"id\": 0,\n      \"name_on_card\": \"\",\n      \"pin_code_assignment\": [\n        {\n          \"monetary_account_id\": 0,\n          \"pin_code\": \"\",\n          \"routing_type\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"second_line\": \"\"\n    }\n  ]\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/card-batch-replace"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"cards\": [\n    {\n      \"id\": 0,\n      \"name_on_card\": \"\",\n      \"pin_code_assignment\": [\n        {\n          \"monetary_account_id\": 0,\n          \"pin_code\": \"\",\n          \"routing_type\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"second_line\": \"\"\n    }\n  ]\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/card-batch-replace");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"cards\": [\n    {\n      \"id\": 0,\n      \"name_on_card\": \"\",\n      \"pin_code_assignment\": [\n        {\n          \"monetary_account_id\": 0,\n          \"pin_code\": \"\",\n          \"routing_type\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"second_line\": \"\"\n    }\n  ]\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/card-batch-replace"

	payload := strings.NewReader("{\n  \"cards\": [\n    {\n      \"id\": 0,\n      \"name_on_card\": \"\",\n      \"pin_code_assignment\": [\n        {\n          \"monetary_account_id\": 0,\n          \"pin_code\": \"\",\n          \"routing_type\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"second_line\": \"\"\n    }\n  ]\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/card-batch-replace HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 270

{
  "cards": [
    {
      "id": 0,
      "name_on_card": "",
      "pin_code_assignment": [
        {
          "monetary_account_id": 0,
          "pin_code": "",
          "routing_type": "",
          "type": ""
        }
      ],
      "second_line": ""
    }
  ]
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/card-batch-replace")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"cards\": [\n    {\n      \"id\": 0,\n      \"name_on_card\": \"\",\n      \"pin_code_assignment\": [\n        {\n          \"monetary_account_id\": 0,\n          \"pin_code\": \"\",\n          \"routing_type\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"second_line\": \"\"\n    }\n  ]\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/card-batch-replace"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"cards\": [\n    {\n      \"id\": 0,\n      \"name_on_card\": \"\",\n      \"pin_code_assignment\": [\n        {\n          \"monetary_account_id\": 0,\n          \"pin_code\": \"\",\n          \"routing_type\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"second_line\": \"\"\n    }\n  ]\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"cards\": [\n    {\n      \"id\": 0,\n      \"name_on_card\": \"\",\n      \"pin_code_assignment\": [\n        {\n          \"monetary_account_id\": 0,\n          \"pin_code\": \"\",\n          \"routing_type\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"second_line\": \"\"\n    }\n  ]\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/card-batch-replace")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/card-batch-replace")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"cards\": [\n    {\n      \"id\": 0,\n      \"name_on_card\": \"\",\n      \"pin_code_assignment\": [\n        {\n          \"monetary_account_id\": 0,\n          \"pin_code\": \"\",\n          \"routing_type\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"second_line\": \"\"\n    }\n  ]\n}")
  .asString();
const data = JSON.stringify({
  cards: [
    {
      id: 0,
      name_on_card: '',
      pin_code_assignment: [
        {
          monetary_account_id: 0,
          pin_code: '',
          routing_type: '',
          type: ''
        }
      ],
      second_line: ''
    }
  ]
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/card-batch-replace');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/card-batch-replace',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    cards: [
      {
        id: 0,
        name_on_card: '',
        pin_code_assignment: [{monetary_account_id: 0, pin_code: '', routing_type: '', type: ''}],
        second_line: ''
      }
    ]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/card-batch-replace';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"cards":[{"id":0,"name_on_card":"","pin_code_assignment":[{"monetary_account_id":0,"pin_code":"","routing_type":"","type":""}],"second_line":""}]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/card-batch-replace',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "cards": [\n    {\n      "id": 0,\n      "name_on_card": "",\n      "pin_code_assignment": [\n        {\n          "monetary_account_id": 0,\n          "pin_code": "",\n          "routing_type": "",\n          "type": ""\n        }\n      ],\n      "second_line": ""\n    }\n  ]\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"cards\": [\n    {\n      \"id\": 0,\n      \"name_on_card\": \"\",\n      \"pin_code_assignment\": [\n        {\n          \"monetary_account_id\": 0,\n          \"pin_code\": \"\",\n          \"routing_type\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"second_line\": \"\"\n    }\n  ]\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/card-batch-replace")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/card-batch-replace',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  cards: [
    {
      id: 0,
      name_on_card: '',
      pin_code_assignment: [{monetary_account_id: 0, pin_code: '', routing_type: '', type: ''}],
      second_line: ''
    }
  ]
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/card-batch-replace',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    cards: [
      {
        id: 0,
        name_on_card: '',
        pin_code_assignment: [{monetary_account_id: 0, pin_code: '', routing_type: '', type: ''}],
        second_line: ''
      }
    ]
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/card-batch-replace');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  cards: [
    {
      id: 0,
      name_on_card: '',
      pin_code_assignment: [
        {
          monetary_account_id: 0,
          pin_code: '',
          routing_type: '',
          type: ''
        }
      ],
      second_line: ''
    }
  ]
});

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}}/user/:userID/card-batch-replace',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    cards: [
      {
        id: 0,
        name_on_card: '',
        pin_code_assignment: [{monetary_account_id: 0, pin_code: '', routing_type: '', type: ''}],
        second_line: ''
      }
    ]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/card-batch-replace';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"cards":[{"id":0,"name_on_card":"","pin_code_assignment":[{"monetary_account_id":0,"pin_code":"","routing_type":"","type":""}],"second_line":""}]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"cards": @[ @{ @"id": @0, @"name_on_card": @"", @"pin_code_assignment": @[ @{ @"monetary_account_id": @0, @"pin_code": @"", @"routing_type": @"", @"type": @"" } ], @"second_line": @"" } ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/card-batch-replace"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/card-batch-replace" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"cards\": [\n    {\n      \"id\": 0,\n      \"name_on_card\": \"\",\n      \"pin_code_assignment\": [\n        {\n          \"monetary_account_id\": 0,\n          \"pin_code\": \"\",\n          \"routing_type\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"second_line\": \"\"\n    }\n  ]\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/card-batch-replace",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'cards' => [
        [
                'id' => 0,
                'name_on_card' => '',
                'pin_code_assignment' => [
                                [
                                                                'monetary_account_id' => 0,
                                                                'pin_code' => '',
                                                                'routing_type' => '',
                                                                'type' => ''
                                ]
                ],
                'second_line' => ''
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/card-batch-replace', [
  'body' => '{
  "cards": [
    {
      "id": 0,
      "name_on_card": "",
      "pin_code_assignment": [
        {
          "monetary_account_id": 0,
          "pin_code": "",
          "routing_type": "",
          "type": ""
        }
      ],
      "second_line": ""
    }
  ]
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/card-batch-replace');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'cards' => [
    [
        'id' => 0,
        'name_on_card' => '',
        'pin_code_assignment' => [
                [
                                'monetary_account_id' => 0,
                                'pin_code' => '',
                                'routing_type' => '',
                                'type' => ''
                ]
        ],
        'second_line' => ''
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'cards' => [
    [
        'id' => 0,
        'name_on_card' => '',
        'pin_code_assignment' => [
                [
                                'monetary_account_id' => 0,
                                'pin_code' => '',
                                'routing_type' => '',
                                'type' => ''
                ]
        ],
        'second_line' => ''
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/card-batch-replace');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/card-batch-replace' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "cards": [
    {
      "id": 0,
      "name_on_card": "",
      "pin_code_assignment": [
        {
          "monetary_account_id": 0,
          "pin_code": "",
          "routing_type": "",
          "type": ""
        }
      ],
      "second_line": ""
    }
  ]
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/card-batch-replace' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "cards": [
    {
      "id": 0,
      "name_on_card": "",
      "pin_code_assignment": [
        {
          "monetary_account_id": 0,
          "pin_code": "",
          "routing_type": "",
          "type": ""
        }
      ],
      "second_line": ""
    }
  ]
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"cards\": [\n    {\n      \"id\": 0,\n      \"name_on_card\": \"\",\n      \"pin_code_assignment\": [\n        {\n          \"monetary_account_id\": 0,\n          \"pin_code\": \"\",\n          \"routing_type\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"second_line\": \"\"\n    }\n  ]\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/card-batch-replace", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/card-batch-replace"

payload = { "cards": [
        {
            "id": 0,
            "name_on_card": "",
            "pin_code_assignment": [
                {
                    "monetary_account_id": 0,
                    "pin_code": "",
                    "routing_type": "",
                    "type": ""
                }
            ],
            "second_line": ""
        }
    ] }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/card-batch-replace"

payload <- "{\n  \"cards\": [\n    {\n      \"id\": 0,\n      \"name_on_card\": \"\",\n      \"pin_code_assignment\": [\n        {\n          \"monetary_account_id\": 0,\n          \"pin_code\": \"\",\n          \"routing_type\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"second_line\": \"\"\n    }\n  ]\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/card-batch-replace")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"cards\": [\n    {\n      \"id\": 0,\n      \"name_on_card\": \"\",\n      \"pin_code_assignment\": [\n        {\n          \"monetary_account_id\": 0,\n          \"pin_code\": \"\",\n          \"routing_type\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"second_line\": \"\"\n    }\n  ]\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/card-batch-replace') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"cards\": [\n    {\n      \"id\": 0,\n      \"name_on_card\": \"\",\n      \"pin_code_assignment\": [\n        {\n          \"monetary_account_id\": 0,\n          \"pin_code\": \"\",\n          \"routing_type\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"second_line\": \"\"\n    }\n  ]\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/card-batch-replace";

    let payload = json!({"cards": (
            json!({
                "id": 0,
                "name_on_card": "",
                "pin_code_assignment": (
                    json!({
                        "monetary_account_id": 0,
                        "pin_code": "",
                        "routing_type": "",
                        "type": ""
                    })
                ),
                "second_line": ""
            })
        )});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/card-batch-replace \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "cards": [
    {
      "id": 0,
      "name_on_card": "",
      "pin_code_assignment": [
        {
          "monetary_account_id": 0,
          "pin_code": "",
          "routing_type": "",
          "type": ""
        }
      ],
      "second_line": ""
    }
  ]
}'
echo '{
  "cards": [
    {
      "id": 0,
      "name_on_card": "",
      "pin_code_assignment": [
        {
          "monetary_account_id": 0,
          "pin_code": "",
          "routing_type": "",
          "type": ""
        }
      ],
      "second_line": ""
    }
  ]
}' |  \
  http POST {{baseUrl}}/user/:userID/card-batch-replace \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "cards": [\n    {\n      "id": 0,\n      "name_on_card": "",\n      "pin_code_assignment": [\n        {\n          "monetary_account_id": 0,\n          "pin_code": "",\n          "routing_type": "",\n          "type": ""\n        }\n      ],\n      "second_line": ""\n    }\n  ]\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/card-batch-replace
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["cards": [
    [
      "id": 0,
      "name_on_card": "",
      "pin_code_assignment": [
        [
          "monetary_account_id": 0,
          "pin_code": "",
          "routing_type": "",
          "type": ""
        ]
      ],
      "second_line": ""
    ]
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/card-batch-replace")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_CardCredit_for_User
{{baseUrl}}/user/:userID/card-credit
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
BODY json

{
  "alias": {
    "name": "",
    "service": "",
    "type": "",
    "value": ""
  },
  "monetary_account_id_fallback": 0,
  "name_on_card": "",
  "order_status": "",
  "pin_code_assignment": [
    {
      "monetary_account_id": 0,
      "pin_code": "",
      "routing_type": "",
      "type": ""
    }
  ],
  "preferred_name_on_card": "",
  "product_type": "",
  "second_line": "",
  "type": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/card-credit");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_id_fallback\": 0,\n  \"name_on_card\": \"\",\n  \"order_status\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"product_type\": \"\",\n  \"second_line\": \"\",\n  \"type\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/card-credit" {:headers {:user-agent ""
                                                                               :x-bunq-client-authentication ""}
                                                                     :content-type :json
                                                                     :form-params {:alias {:name ""
                                                                                           :service ""
                                                                                           :type ""
                                                                                           :value ""}
                                                                                   :monetary_account_id_fallback 0
                                                                                   :name_on_card ""
                                                                                   :order_status ""
                                                                                   :pin_code_assignment [{:monetary_account_id 0
                                                                                                          :pin_code ""
                                                                                                          :routing_type ""
                                                                                                          :type ""}]
                                                                                   :preferred_name_on_card ""
                                                                                   :product_type ""
                                                                                   :second_line ""
                                                                                   :type ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/card-credit"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_id_fallback\": 0,\n  \"name_on_card\": \"\",\n  \"order_status\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"product_type\": \"\",\n  \"second_line\": \"\",\n  \"type\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/card-credit"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_id_fallback\": 0,\n  \"name_on_card\": \"\",\n  \"order_status\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"product_type\": \"\",\n  \"second_line\": \"\",\n  \"type\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/card-credit");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_id_fallback\": 0,\n  \"name_on_card\": \"\",\n  \"order_status\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"product_type\": \"\",\n  \"second_line\": \"\",\n  \"type\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/card-credit"

	payload := strings.NewReader("{\n  \"alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_id_fallback\": 0,\n  \"name_on_card\": \"\",\n  \"order_status\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"product_type\": \"\",\n  \"second_line\": \"\",\n  \"type\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/card-credit HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 398

{
  "alias": {
    "name": "",
    "service": "",
    "type": "",
    "value": ""
  },
  "monetary_account_id_fallback": 0,
  "name_on_card": "",
  "order_status": "",
  "pin_code_assignment": [
    {
      "monetary_account_id": 0,
      "pin_code": "",
      "routing_type": "",
      "type": ""
    }
  ],
  "preferred_name_on_card": "",
  "product_type": "",
  "second_line": "",
  "type": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/card-credit")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_id_fallback\": 0,\n  \"name_on_card\": \"\",\n  \"order_status\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"product_type\": \"\",\n  \"second_line\": \"\",\n  \"type\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/card-credit"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_id_fallback\": 0,\n  \"name_on_card\": \"\",\n  \"order_status\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"product_type\": \"\",\n  \"second_line\": \"\",\n  \"type\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_id_fallback\": 0,\n  \"name_on_card\": \"\",\n  \"order_status\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"product_type\": \"\",\n  \"second_line\": \"\",\n  \"type\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/card-credit")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/card-credit")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_id_fallback\": 0,\n  \"name_on_card\": \"\",\n  \"order_status\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"product_type\": \"\",\n  \"second_line\": \"\",\n  \"type\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  alias: {
    name: '',
    service: '',
    type: '',
    value: ''
  },
  monetary_account_id_fallback: 0,
  name_on_card: '',
  order_status: '',
  pin_code_assignment: [
    {
      monetary_account_id: 0,
      pin_code: '',
      routing_type: '',
      type: ''
    }
  ],
  preferred_name_on_card: '',
  product_type: '',
  second_line: '',
  type: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/card-credit');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/card-credit',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    alias: {name: '', service: '', type: '', value: ''},
    monetary_account_id_fallback: 0,
    name_on_card: '',
    order_status: '',
    pin_code_assignment: [{monetary_account_id: 0, pin_code: '', routing_type: '', type: ''}],
    preferred_name_on_card: '',
    product_type: '',
    second_line: '',
    type: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/card-credit';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"alias":{"name":"","service":"","type":"","value":""},"monetary_account_id_fallback":0,"name_on_card":"","order_status":"","pin_code_assignment":[{"monetary_account_id":0,"pin_code":"","routing_type":"","type":""}],"preferred_name_on_card":"","product_type":"","second_line":"","type":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/card-credit',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "alias": {\n    "name": "",\n    "service": "",\n    "type": "",\n    "value": ""\n  },\n  "monetary_account_id_fallback": 0,\n  "name_on_card": "",\n  "order_status": "",\n  "pin_code_assignment": [\n    {\n      "monetary_account_id": 0,\n      "pin_code": "",\n      "routing_type": "",\n      "type": ""\n    }\n  ],\n  "preferred_name_on_card": "",\n  "product_type": "",\n  "second_line": "",\n  "type": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_id_fallback\": 0,\n  \"name_on_card\": \"\",\n  \"order_status\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"product_type\": \"\",\n  \"second_line\": \"\",\n  \"type\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/card-credit")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/card-credit',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  alias: {name: '', service: '', type: '', value: ''},
  monetary_account_id_fallback: 0,
  name_on_card: '',
  order_status: '',
  pin_code_assignment: [{monetary_account_id: 0, pin_code: '', routing_type: '', type: ''}],
  preferred_name_on_card: '',
  product_type: '',
  second_line: '',
  type: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/card-credit',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    alias: {name: '', service: '', type: '', value: ''},
    monetary_account_id_fallback: 0,
    name_on_card: '',
    order_status: '',
    pin_code_assignment: [{monetary_account_id: 0, pin_code: '', routing_type: '', type: ''}],
    preferred_name_on_card: '',
    product_type: '',
    second_line: '',
    type: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/card-credit');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  alias: {
    name: '',
    service: '',
    type: '',
    value: ''
  },
  monetary_account_id_fallback: 0,
  name_on_card: '',
  order_status: '',
  pin_code_assignment: [
    {
      monetary_account_id: 0,
      pin_code: '',
      routing_type: '',
      type: ''
    }
  ],
  preferred_name_on_card: '',
  product_type: '',
  second_line: '',
  type: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/card-credit',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    alias: {name: '', service: '', type: '', value: ''},
    monetary_account_id_fallback: 0,
    name_on_card: '',
    order_status: '',
    pin_code_assignment: [{monetary_account_id: 0, pin_code: '', routing_type: '', type: ''}],
    preferred_name_on_card: '',
    product_type: '',
    second_line: '',
    type: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/card-credit';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"alias":{"name":"","service":"","type":"","value":""},"monetary_account_id_fallback":0,"name_on_card":"","order_status":"","pin_code_assignment":[{"monetary_account_id":0,"pin_code":"","routing_type":"","type":""}],"preferred_name_on_card":"","product_type":"","second_line":"","type":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"alias": @{ @"name": @"", @"service": @"", @"type": @"", @"value": @"" },
                              @"monetary_account_id_fallback": @0,
                              @"name_on_card": @"",
                              @"order_status": @"",
                              @"pin_code_assignment": @[ @{ @"monetary_account_id": @0, @"pin_code": @"", @"routing_type": @"", @"type": @"" } ],
                              @"preferred_name_on_card": @"",
                              @"product_type": @"",
                              @"second_line": @"",
                              @"type": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/card-credit"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/card-credit" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_id_fallback\": 0,\n  \"name_on_card\": \"\",\n  \"order_status\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"product_type\": \"\",\n  \"second_line\": \"\",\n  \"type\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/card-credit",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'alias' => [
        'name' => '',
        'service' => '',
        'type' => '',
        'value' => ''
    ],
    'monetary_account_id_fallback' => 0,
    'name_on_card' => '',
    'order_status' => '',
    'pin_code_assignment' => [
        [
                'monetary_account_id' => 0,
                'pin_code' => '',
                'routing_type' => '',
                'type' => ''
        ]
    ],
    'preferred_name_on_card' => '',
    'product_type' => '',
    'second_line' => '',
    'type' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/card-credit', [
  'body' => '{
  "alias": {
    "name": "",
    "service": "",
    "type": "",
    "value": ""
  },
  "monetary_account_id_fallback": 0,
  "name_on_card": "",
  "order_status": "",
  "pin_code_assignment": [
    {
      "monetary_account_id": 0,
      "pin_code": "",
      "routing_type": "",
      "type": ""
    }
  ],
  "preferred_name_on_card": "",
  "product_type": "",
  "second_line": "",
  "type": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/card-credit');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'alias' => [
    'name' => '',
    'service' => '',
    'type' => '',
    'value' => ''
  ],
  'monetary_account_id_fallback' => 0,
  'name_on_card' => '',
  'order_status' => '',
  'pin_code_assignment' => [
    [
        'monetary_account_id' => 0,
        'pin_code' => '',
        'routing_type' => '',
        'type' => ''
    ]
  ],
  'preferred_name_on_card' => '',
  'product_type' => '',
  'second_line' => '',
  'type' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'alias' => [
    'name' => '',
    'service' => '',
    'type' => '',
    'value' => ''
  ],
  'monetary_account_id_fallback' => 0,
  'name_on_card' => '',
  'order_status' => '',
  'pin_code_assignment' => [
    [
        'monetary_account_id' => 0,
        'pin_code' => '',
        'routing_type' => '',
        'type' => ''
    ]
  ],
  'preferred_name_on_card' => '',
  'product_type' => '',
  'second_line' => '',
  'type' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/card-credit');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/card-credit' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "alias": {
    "name": "",
    "service": "",
    "type": "",
    "value": ""
  },
  "monetary_account_id_fallback": 0,
  "name_on_card": "",
  "order_status": "",
  "pin_code_assignment": [
    {
      "monetary_account_id": 0,
      "pin_code": "",
      "routing_type": "",
      "type": ""
    }
  ],
  "preferred_name_on_card": "",
  "product_type": "",
  "second_line": "",
  "type": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/card-credit' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "alias": {
    "name": "",
    "service": "",
    "type": "",
    "value": ""
  },
  "monetary_account_id_fallback": 0,
  "name_on_card": "",
  "order_status": "",
  "pin_code_assignment": [
    {
      "monetary_account_id": 0,
      "pin_code": "",
      "routing_type": "",
      "type": ""
    }
  ],
  "preferred_name_on_card": "",
  "product_type": "",
  "second_line": "",
  "type": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_id_fallback\": 0,\n  \"name_on_card\": \"\",\n  \"order_status\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"product_type\": \"\",\n  \"second_line\": \"\",\n  \"type\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/card-credit", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/card-credit"

payload = {
    "alias": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
    },
    "monetary_account_id_fallback": 0,
    "name_on_card": "",
    "order_status": "",
    "pin_code_assignment": [
        {
            "monetary_account_id": 0,
            "pin_code": "",
            "routing_type": "",
            "type": ""
        }
    ],
    "preferred_name_on_card": "",
    "product_type": "",
    "second_line": "",
    "type": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/card-credit"

payload <- "{\n  \"alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_id_fallback\": 0,\n  \"name_on_card\": \"\",\n  \"order_status\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"product_type\": \"\",\n  \"second_line\": \"\",\n  \"type\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/card-credit")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_id_fallback\": 0,\n  \"name_on_card\": \"\",\n  \"order_status\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"product_type\": \"\",\n  \"second_line\": \"\",\n  \"type\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/card-credit') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_id_fallback\": 0,\n  \"name_on_card\": \"\",\n  \"order_status\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"product_type\": \"\",\n  \"second_line\": \"\",\n  \"type\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/card-credit";

    let payload = json!({
        "alias": json!({
            "name": "",
            "service": "",
            "type": "",
            "value": ""
        }),
        "monetary_account_id_fallback": 0,
        "name_on_card": "",
        "order_status": "",
        "pin_code_assignment": (
            json!({
                "monetary_account_id": 0,
                "pin_code": "",
                "routing_type": "",
                "type": ""
            })
        ),
        "preferred_name_on_card": "",
        "product_type": "",
        "second_line": "",
        "type": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/card-credit \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "alias": {
    "name": "",
    "service": "",
    "type": "",
    "value": ""
  },
  "monetary_account_id_fallback": 0,
  "name_on_card": "",
  "order_status": "",
  "pin_code_assignment": [
    {
      "monetary_account_id": 0,
      "pin_code": "",
      "routing_type": "",
      "type": ""
    }
  ],
  "preferred_name_on_card": "",
  "product_type": "",
  "second_line": "",
  "type": ""
}'
echo '{
  "alias": {
    "name": "",
    "service": "",
    "type": "",
    "value": ""
  },
  "monetary_account_id_fallback": 0,
  "name_on_card": "",
  "order_status": "",
  "pin_code_assignment": [
    {
      "monetary_account_id": 0,
      "pin_code": "",
      "routing_type": "",
      "type": ""
    }
  ],
  "preferred_name_on_card": "",
  "product_type": "",
  "second_line": "",
  "type": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/card-credit \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "alias": {\n    "name": "",\n    "service": "",\n    "type": "",\n    "value": ""\n  },\n  "monetary_account_id_fallback": 0,\n  "name_on_card": "",\n  "order_status": "",\n  "pin_code_assignment": [\n    {\n      "monetary_account_id": 0,\n      "pin_code": "",\n      "routing_type": "",\n      "type": ""\n    }\n  ],\n  "preferred_name_on_card": "",\n  "product_type": "",\n  "second_line": "",\n  "type": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/card-credit
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "alias": [
    "name": "",
    "service": "",
    "type": "",
    "value": ""
  ],
  "monetary_account_id_fallback": 0,
  "name_on_card": "",
  "order_status": "",
  "pin_code_assignment": [
    [
      "monetary_account_id": 0,
      "pin_code": "",
      "routing_type": "",
      "type": ""
    ]
  ],
  "preferred_name_on_card": "",
  "product_type": "",
  "second_line": "",
  "type": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/card-credit")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_CardDebit_for_User
{{baseUrl}}/user/:userID/card-debit
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
BODY json

{
  "alias": {
    "name": "",
    "service": "",
    "type": "",
    "value": ""
  },
  "monetary_account_id_fallback": 0,
  "name_on_card": "",
  "order_status": "",
  "pin_code_assignment": [
    {
      "monetary_account_id": 0,
      "pin_code": "",
      "routing_type": "",
      "type": ""
    }
  ],
  "preferred_name_on_card": "",
  "product_type": "",
  "second_line": "",
  "type": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/card-debit");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_id_fallback\": 0,\n  \"name_on_card\": \"\",\n  \"order_status\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"product_type\": \"\",\n  \"second_line\": \"\",\n  \"type\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/card-debit" {:headers {:user-agent ""
                                                                              :x-bunq-client-authentication ""}
                                                                    :content-type :json
                                                                    :form-params {:alias {:name ""
                                                                                          :service ""
                                                                                          :type ""
                                                                                          :value ""}
                                                                                  :monetary_account_id_fallback 0
                                                                                  :name_on_card ""
                                                                                  :order_status ""
                                                                                  :pin_code_assignment [{:monetary_account_id 0
                                                                                                         :pin_code ""
                                                                                                         :routing_type ""
                                                                                                         :type ""}]
                                                                                  :preferred_name_on_card ""
                                                                                  :product_type ""
                                                                                  :second_line ""
                                                                                  :type ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/card-debit"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_id_fallback\": 0,\n  \"name_on_card\": \"\",\n  \"order_status\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"product_type\": \"\",\n  \"second_line\": \"\",\n  \"type\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/card-debit"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_id_fallback\": 0,\n  \"name_on_card\": \"\",\n  \"order_status\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"product_type\": \"\",\n  \"second_line\": \"\",\n  \"type\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/card-debit");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_id_fallback\": 0,\n  \"name_on_card\": \"\",\n  \"order_status\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"product_type\": \"\",\n  \"second_line\": \"\",\n  \"type\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/card-debit"

	payload := strings.NewReader("{\n  \"alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_id_fallback\": 0,\n  \"name_on_card\": \"\",\n  \"order_status\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"product_type\": \"\",\n  \"second_line\": \"\",\n  \"type\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/card-debit HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 398

{
  "alias": {
    "name": "",
    "service": "",
    "type": "",
    "value": ""
  },
  "monetary_account_id_fallback": 0,
  "name_on_card": "",
  "order_status": "",
  "pin_code_assignment": [
    {
      "monetary_account_id": 0,
      "pin_code": "",
      "routing_type": "",
      "type": ""
    }
  ],
  "preferred_name_on_card": "",
  "product_type": "",
  "second_line": "",
  "type": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/card-debit")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_id_fallback\": 0,\n  \"name_on_card\": \"\",\n  \"order_status\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"product_type\": \"\",\n  \"second_line\": \"\",\n  \"type\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/card-debit"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_id_fallback\": 0,\n  \"name_on_card\": \"\",\n  \"order_status\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"product_type\": \"\",\n  \"second_line\": \"\",\n  \"type\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_id_fallback\": 0,\n  \"name_on_card\": \"\",\n  \"order_status\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"product_type\": \"\",\n  \"second_line\": \"\",\n  \"type\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/card-debit")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/card-debit")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_id_fallback\": 0,\n  \"name_on_card\": \"\",\n  \"order_status\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"product_type\": \"\",\n  \"second_line\": \"\",\n  \"type\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  alias: {
    name: '',
    service: '',
    type: '',
    value: ''
  },
  monetary_account_id_fallback: 0,
  name_on_card: '',
  order_status: '',
  pin_code_assignment: [
    {
      monetary_account_id: 0,
      pin_code: '',
      routing_type: '',
      type: ''
    }
  ],
  preferred_name_on_card: '',
  product_type: '',
  second_line: '',
  type: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/card-debit');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/card-debit',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    alias: {name: '', service: '', type: '', value: ''},
    monetary_account_id_fallback: 0,
    name_on_card: '',
    order_status: '',
    pin_code_assignment: [{monetary_account_id: 0, pin_code: '', routing_type: '', type: ''}],
    preferred_name_on_card: '',
    product_type: '',
    second_line: '',
    type: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/card-debit';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"alias":{"name":"","service":"","type":"","value":""},"monetary_account_id_fallback":0,"name_on_card":"","order_status":"","pin_code_assignment":[{"monetary_account_id":0,"pin_code":"","routing_type":"","type":""}],"preferred_name_on_card":"","product_type":"","second_line":"","type":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/card-debit',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "alias": {\n    "name": "",\n    "service": "",\n    "type": "",\n    "value": ""\n  },\n  "monetary_account_id_fallback": 0,\n  "name_on_card": "",\n  "order_status": "",\n  "pin_code_assignment": [\n    {\n      "monetary_account_id": 0,\n      "pin_code": "",\n      "routing_type": "",\n      "type": ""\n    }\n  ],\n  "preferred_name_on_card": "",\n  "product_type": "",\n  "second_line": "",\n  "type": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_id_fallback\": 0,\n  \"name_on_card\": \"\",\n  \"order_status\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"product_type\": \"\",\n  \"second_line\": \"\",\n  \"type\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/card-debit")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/card-debit',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  alias: {name: '', service: '', type: '', value: ''},
  monetary_account_id_fallback: 0,
  name_on_card: '',
  order_status: '',
  pin_code_assignment: [{monetary_account_id: 0, pin_code: '', routing_type: '', type: ''}],
  preferred_name_on_card: '',
  product_type: '',
  second_line: '',
  type: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/card-debit',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    alias: {name: '', service: '', type: '', value: ''},
    monetary_account_id_fallback: 0,
    name_on_card: '',
    order_status: '',
    pin_code_assignment: [{monetary_account_id: 0, pin_code: '', routing_type: '', type: ''}],
    preferred_name_on_card: '',
    product_type: '',
    second_line: '',
    type: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/card-debit');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  alias: {
    name: '',
    service: '',
    type: '',
    value: ''
  },
  monetary_account_id_fallback: 0,
  name_on_card: '',
  order_status: '',
  pin_code_assignment: [
    {
      monetary_account_id: 0,
      pin_code: '',
      routing_type: '',
      type: ''
    }
  ],
  preferred_name_on_card: '',
  product_type: '',
  second_line: '',
  type: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/card-debit',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    alias: {name: '', service: '', type: '', value: ''},
    monetary_account_id_fallback: 0,
    name_on_card: '',
    order_status: '',
    pin_code_assignment: [{monetary_account_id: 0, pin_code: '', routing_type: '', type: ''}],
    preferred_name_on_card: '',
    product_type: '',
    second_line: '',
    type: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/card-debit';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"alias":{"name":"","service":"","type":"","value":""},"monetary_account_id_fallback":0,"name_on_card":"","order_status":"","pin_code_assignment":[{"monetary_account_id":0,"pin_code":"","routing_type":"","type":""}],"preferred_name_on_card":"","product_type":"","second_line":"","type":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"alias": @{ @"name": @"", @"service": @"", @"type": @"", @"value": @"" },
                              @"monetary_account_id_fallback": @0,
                              @"name_on_card": @"",
                              @"order_status": @"",
                              @"pin_code_assignment": @[ @{ @"monetary_account_id": @0, @"pin_code": @"", @"routing_type": @"", @"type": @"" } ],
                              @"preferred_name_on_card": @"",
                              @"product_type": @"",
                              @"second_line": @"",
                              @"type": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/card-debit"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/card-debit" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_id_fallback\": 0,\n  \"name_on_card\": \"\",\n  \"order_status\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"product_type\": \"\",\n  \"second_line\": \"\",\n  \"type\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/card-debit",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'alias' => [
        'name' => '',
        'service' => '',
        'type' => '',
        'value' => ''
    ],
    'monetary_account_id_fallback' => 0,
    'name_on_card' => '',
    'order_status' => '',
    'pin_code_assignment' => [
        [
                'monetary_account_id' => 0,
                'pin_code' => '',
                'routing_type' => '',
                'type' => ''
        ]
    ],
    'preferred_name_on_card' => '',
    'product_type' => '',
    'second_line' => '',
    'type' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/card-debit', [
  'body' => '{
  "alias": {
    "name": "",
    "service": "",
    "type": "",
    "value": ""
  },
  "monetary_account_id_fallback": 0,
  "name_on_card": "",
  "order_status": "",
  "pin_code_assignment": [
    {
      "monetary_account_id": 0,
      "pin_code": "",
      "routing_type": "",
      "type": ""
    }
  ],
  "preferred_name_on_card": "",
  "product_type": "",
  "second_line": "",
  "type": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/card-debit');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'alias' => [
    'name' => '',
    'service' => '',
    'type' => '',
    'value' => ''
  ],
  'monetary_account_id_fallback' => 0,
  'name_on_card' => '',
  'order_status' => '',
  'pin_code_assignment' => [
    [
        'monetary_account_id' => 0,
        'pin_code' => '',
        'routing_type' => '',
        'type' => ''
    ]
  ],
  'preferred_name_on_card' => '',
  'product_type' => '',
  'second_line' => '',
  'type' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'alias' => [
    'name' => '',
    'service' => '',
    'type' => '',
    'value' => ''
  ],
  'monetary_account_id_fallback' => 0,
  'name_on_card' => '',
  'order_status' => '',
  'pin_code_assignment' => [
    [
        'monetary_account_id' => 0,
        'pin_code' => '',
        'routing_type' => '',
        'type' => ''
    ]
  ],
  'preferred_name_on_card' => '',
  'product_type' => '',
  'second_line' => '',
  'type' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/card-debit');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/card-debit' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "alias": {
    "name": "",
    "service": "",
    "type": "",
    "value": ""
  },
  "monetary_account_id_fallback": 0,
  "name_on_card": "",
  "order_status": "",
  "pin_code_assignment": [
    {
      "monetary_account_id": 0,
      "pin_code": "",
      "routing_type": "",
      "type": ""
    }
  ],
  "preferred_name_on_card": "",
  "product_type": "",
  "second_line": "",
  "type": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/card-debit' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "alias": {
    "name": "",
    "service": "",
    "type": "",
    "value": ""
  },
  "monetary_account_id_fallback": 0,
  "name_on_card": "",
  "order_status": "",
  "pin_code_assignment": [
    {
      "monetary_account_id": 0,
      "pin_code": "",
      "routing_type": "",
      "type": ""
    }
  ],
  "preferred_name_on_card": "",
  "product_type": "",
  "second_line": "",
  "type": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_id_fallback\": 0,\n  \"name_on_card\": \"\",\n  \"order_status\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"product_type\": \"\",\n  \"second_line\": \"\",\n  \"type\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/card-debit", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/card-debit"

payload = {
    "alias": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
    },
    "monetary_account_id_fallback": 0,
    "name_on_card": "",
    "order_status": "",
    "pin_code_assignment": [
        {
            "monetary_account_id": 0,
            "pin_code": "",
            "routing_type": "",
            "type": ""
        }
    ],
    "preferred_name_on_card": "",
    "product_type": "",
    "second_line": "",
    "type": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/card-debit"

payload <- "{\n  \"alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_id_fallback\": 0,\n  \"name_on_card\": \"\",\n  \"order_status\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"product_type\": \"\",\n  \"second_line\": \"\",\n  \"type\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/card-debit")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_id_fallback\": 0,\n  \"name_on_card\": \"\",\n  \"order_status\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"product_type\": \"\",\n  \"second_line\": \"\",\n  \"type\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/card-debit') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_id_fallback\": 0,\n  \"name_on_card\": \"\",\n  \"order_status\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"product_type\": \"\",\n  \"second_line\": \"\",\n  \"type\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/card-debit";

    let payload = json!({
        "alias": json!({
            "name": "",
            "service": "",
            "type": "",
            "value": ""
        }),
        "monetary_account_id_fallback": 0,
        "name_on_card": "",
        "order_status": "",
        "pin_code_assignment": (
            json!({
                "monetary_account_id": 0,
                "pin_code": "",
                "routing_type": "",
                "type": ""
            })
        ),
        "preferred_name_on_card": "",
        "product_type": "",
        "second_line": "",
        "type": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/card-debit \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "alias": {
    "name": "",
    "service": "",
    "type": "",
    "value": ""
  },
  "monetary_account_id_fallback": 0,
  "name_on_card": "",
  "order_status": "",
  "pin_code_assignment": [
    {
      "monetary_account_id": 0,
      "pin_code": "",
      "routing_type": "",
      "type": ""
    }
  ],
  "preferred_name_on_card": "",
  "product_type": "",
  "second_line": "",
  "type": ""
}'
echo '{
  "alias": {
    "name": "",
    "service": "",
    "type": "",
    "value": ""
  },
  "monetary_account_id_fallback": 0,
  "name_on_card": "",
  "order_status": "",
  "pin_code_assignment": [
    {
      "monetary_account_id": 0,
      "pin_code": "",
      "routing_type": "",
      "type": ""
    }
  ],
  "preferred_name_on_card": "",
  "product_type": "",
  "second_line": "",
  "type": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/card-debit \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "alias": {\n    "name": "",\n    "service": "",\n    "type": "",\n    "value": ""\n  },\n  "monetary_account_id_fallback": 0,\n  "name_on_card": "",\n  "order_status": "",\n  "pin_code_assignment": [\n    {\n      "monetary_account_id": 0,\n      "pin_code": "",\n      "routing_type": "",\n      "type": ""\n    }\n  ],\n  "preferred_name_on_card": "",\n  "product_type": "",\n  "second_line": "",\n  "type": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/card-debit
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "alias": [
    "name": "",
    "service": "",
    "type": "",
    "value": ""
  ],
  "monetary_account_id_fallback": 0,
  "name_on_card": "",
  "order_status": "",
  "pin_code_assignment": [
    [
      "monetary_account_id": 0,
      "pin_code": "",
      "routing_type": "",
      "type": ""
    ]
  ],
  "preferred_name_on_card": "",
  "product_type": "",
  "second_line": "",
  "type": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/card-debit")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_CardName_for_User
{{baseUrl}}/user/:userID/card-name
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/card-name");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/card-name" {:headers {:user-agent ""
                                                                            :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/card-name"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/card-name"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/card-name");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/card-name"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/card-name HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/card-name")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/card-name"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/card-name")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/card-name")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/card-name');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/card-name',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/card-name';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/card-name',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/card-name")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/card-name',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/card-name',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/card-name');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/card-name',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/card-name';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/card-name"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/card-name" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/card-name",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/card-name', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/card-name');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/card-name');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/card-name' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/card-name' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/card-name", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/card-name"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/card-name"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/card-name")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/card-name') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/card-name";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/card-name \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/card-name \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/card-name
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/card-name")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_CertificatePinned_for_User
{{baseUrl}}/user/:userID/certificate-pinned
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
BODY json

{
  "certificate_chain": [
    {
      "certificate": ""
    }
  ]
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/certificate-pinned");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"certificate_chain\": [\n    {\n      \"certificate\": \"\"\n    }\n  ]\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/certificate-pinned" {:headers {:user-agent ""
                                                                                      :x-bunq-client-authentication ""}
                                                                            :content-type :json
                                                                            :form-params {:certificate_chain [{:certificate ""}]}})
require "http/client"

url = "{{baseUrl}}/user/:userID/certificate-pinned"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"certificate_chain\": [\n    {\n      \"certificate\": \"\"\n    }\n  ]\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/certificate-pinned"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"certificate_chain\": [\n    {\n      \"certificate\": \"\"\n    }\n  ]\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/certificate-pinned");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"certificate_chain\": [\n    {\n      \"certificate\": \"\"\n    }\n  ]\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/certificate-pinned"

	payload := strings.NewReader("{\n  \"certificate_chain\": [\n    {\n      \"certificate\": \"\"\n    }\n  ]\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/certificate-pinned HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 68

{
  "certificate_chain": [
    {
      "certificate": ""
    }
  ]
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/certificate-pinned")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"certificate_chain\": [\n    {\n      \"certificate\": \"\"\n    }\n  ]\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/certificate-pinned"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"certificate_chain\": [\n    {\n      \"certificate\": \"\"\n    }\n  ]\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"certificate_chain\": [\n    {\n      \"certificate\": \"\"\n    }\n  ]\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/certificate-pinned")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/certificate-pinned")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"certificate_chain\": [\n    {\n      \"certificate\": \"\"\n    }\n  ]\n}")
  .asString();
const data = JSON.stringify({
  certificate_chain: [
    {
      certificate: ''
    }
  ]
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/certificate-pinned');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/certificate-pinned',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {certificate_chain: [{certificate: ''}]}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/certificate-pinned';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"certificate_chain":[{"certificate":""}]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/certificate-pinned',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "certificate_chain": [\n    {\n      "certificate": ""\n    }\n  ]\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"certificate_chain\": [\n    {\n      \"certificate\": \"\"\n    }\n  ]\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/certificate-pinned")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/certificate-pinned',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({certificate_chain: [{certificate: ''}]}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/certificate-pinned',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {certificate_chain: [{certificate: ''}]},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/certificate-pinned');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  certificate_chain: [
    {
      certificate: ''
    }
  ]
});

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}}/user/:userID/certificate-pinned',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {certificate_chain: [{certificate: ''}]}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/certificate-pinned';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"certificate_chain":[{"certificate":""}]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"certificate_chain": @[ @{ @"certificate": @"" } ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/certificate-pinned"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/certificate-pinned" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"certificate_chain\": [\n    {\n      \"certificate\": \"\"\n    }\n  ]\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/certificate-pinned",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'certificate_chain' => [
        [
                'certificate' => ''
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/certificate-pinned', [
  'body' => '{
  "certificate_chain": [
    {
      "certificate": ""
    }
  ]
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/certificate-pinned');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'certificate_chain' => [
    [
        'certificate' => ''
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'certificate_chain' => [
    [
        'certificate' => ''
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/certificate-pinned');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/certificate-pinned' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificate_chain": [
    {
      "certificate": ""
    }
  ]
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/certificate-pinned' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "certificate_chain": [
    {
      "certificate": ""
    }
  ]
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"certificate_chain\": [\n    {\n      \"certificate\": \"\"\n    }\n  ]\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/certificate-pinned", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/certificate-pinned"

payload = { "certificate_chain": [{ "certificate": "" }] }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/certificate-pinned"

payload <- "{\n  \"certificate_chain\": [\n    {\n      \"certificate\": \"\"\n    }\n  ]\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/certificate-pinned")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"certificate_chain\": [\n    {\n      \"certificate\": \"\"\n    }\n  ]\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/certificate-pinned') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"certificate_chain\": [\n    {\n      \"certificate\": \"\"\n    }\n  ]\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/certificate-pinned";

    let payload = json!({"certificate_chain": (json!({"certificate": ""}))});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/certificate-pinned \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "certificate_chain": [
    {
      "certificate": ""
    }
  ]
}'
echo '{
  "certificate_chain": [
    {
      "certificate": ""
    }
  ]
}' |  \
  http POST {{baseUrl}}/user/:userID/certificate-pinned \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "certificate_chain": [\n    {\n      "certificate": ""\n    }\n  ]\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/certificate-pinned
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["certificate_chain": [["certificate": ""]]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/certificate-pinned")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_CertificatePinned_for_User
{{baseUrl}}/user/:userID/certificate-pinned/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/certificate-pinned/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/certificate-pinned/:itemId" {:headers {:user-agent ""
                                                                                                :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/certificate-pinned/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/certificate-pinned/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/certificate-pinned/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/certificate-pinned/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/certificate-pinned/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/certificate-pinned/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/certificate-pinned/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/certificate-pinned/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/certificate-pinned/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/certificate-pinned/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/certificate-pinned/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/certificate-pinned/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/certificate-pinned/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/certificate-pinned/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/certificate-pinned/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/certificate-pinned/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/certificate-pinned/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/certificate-pinned/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/certificate-pinned/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/certificate-pinned/:itemId"]
                                                       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}}/user/:userID/certificate-pinned/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/certificate-pinned/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/certificate-pinned/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/certificate-pinned/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/certificate-pinned/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/certificate-pinned/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/certificate-pinned/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/certificate-pinned/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/certificate-pinned/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/certificate-pinned/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/certificate-pinned/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/certificate-pinned/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/certificate-pinned/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/certificate-pinned/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/certificate-pinned/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/certificate-pinned/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/certificate-pinned/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_CertificatePinned_for_User
{{baseUrl}}/user/:userID/certificate-pinned
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/certificate-pinned");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/certificate-pinned" {:headers {:user-agent ""
                                                                                     :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/certificate-pinned"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/certificate-pinned"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/certificate-pinned");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/certificate-pinned"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/certificate-pinned HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/certificate-pinned")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/certificate-pinned"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/certificate-pinned")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/certificate-pinned")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/certificate-pinned');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/certificate-pinned',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/certificate-pinned';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/certificate-pinned',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/certificate-pinned")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/certificate-pinned',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/certificate-pinned',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/certificate-pinned');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/certificate-pinned',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/certificate-pinned';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/certificate-pinned"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/certificate-pinned" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/certificate-pinned",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/certificate-pinned', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/certificate-pinned');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/certificate-pinned');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/certificate-pinned' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/certificate-pinned' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/certificate-pinned", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/certificate-pinned"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/certificate-pinned"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/certificate-pinned")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/certificate-pinned') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/certificate-pinned";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/certificate-pinned \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/certificate-pinned \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/certificate-pinned
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/certificate-pinned")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_CertificatePinned_for_User
{{baseUrl}}/user/:userID/certificate-pinned/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/certificate-pinned/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/certificate-pinned/:itemId" {:headers {:user-agent ""
                                                                                             :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/certificate-pinned/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/certificate-pinned/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/certificate-pinned/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/certificate-pinned/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/certificate-pinned/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/certificate-pinned/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/certificate-pinned/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/certificate-pinned/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/certificate-pinned/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/certificate-pinned/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/certificate-pinned/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/certificate-pinned/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/certificate-pinned/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/certificate-pinned/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/certificate-pinned/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/certificate-pinned/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/certificate-pinned/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/certificate-pinned/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/certificate-pinned/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/certificate-pinned/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/certificate-pinned/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/certificate-pinned/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/certificate-pinned/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/certificate-pinned/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/certificate-pinned/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/certificate-pinned/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/certificate-pinned/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/certificate-pinned/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/certificate-pinned/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/certificate-pinned/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/certificate-pinned/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/certificate-pinned/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/certificate-pinned/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/certificate-pinned/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/certificate-pinned/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/certificate-pinned/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/certificate-pinned/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_ChallengeRequest_for_User
{{baseUrl}}/user/:userID/challenge-request/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/challenge-request/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/challenge-request/:itemId" {:headers {:user-agent ""
                                                                                            :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/challenge-request/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/challenge-request/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/challenge-request/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/challenge-request/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/challenge-request/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/challenge-request/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/challenge-request/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/challenge-request/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/challenge-request/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/challenge-request/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/challenge-request/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/challenge-request/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/challenge-request/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/challenge-request/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/challenge-request/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/challenge-request/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/challenge-request/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/challenge-request/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/challenge-request/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/challenge-request/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/challenge-request/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/challenge-request/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/challenge-request/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/challenge-request/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/challenge-request/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/challenge-request/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/challenge-request/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/challenge-request/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/challenge-request/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/challenge-request/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/challenge-request/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/challenge-request/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/challenge-request/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/challenge-request/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/challenge-request/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/challenge-request/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/challenge-request/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_ChallengeRequest_for_User
{{baseUrl}}/user/:userID/challenge-request/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
BODY json

{
  "status": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/challenge-request/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"status\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/challenge-request/:itemId" {:headers {:user-agent ""
                                                                                            :x-bunq-client-authentication ""}
                                                                                  :content-type :json
                                                                                  :form-params {:status ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/challenge-request/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"status\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/challenge-request/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"status\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/challenge-request/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"status\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/challenge-request/:itemId"

	payload := strings.NewReader("{\n  \"status\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/challenge-request/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 18

{
  "status": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/challenge-request/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"status\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/challenge-request/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"status\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"status\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/challenge-request/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/challenge-request/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"status\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  status: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/challenge-request/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/challenge-request/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {status: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/challenge-request/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/challenge-request/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "status": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"status\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/challenge-request/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/challenge-request/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({status: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/challenge-request/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {status: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/challenge-request/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  status: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/challenge-request/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {status: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/challenge-request/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"status": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/challenge-request/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/challenge-request/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"status\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/challenge-request/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'status' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/challenge-request/:itemId', [
  'body' => '{
  "status": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/challenge-request/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'status' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'status' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/challenge-request/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/challenge-request/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "status": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/challenge-request/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "status": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"status\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/challenge-request/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/challenge-request/:itemId"

payload = { "status": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/challenge-request/:itemId"

payload <- "{\n  \"status\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/challenge-request/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"status\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/challenge-request/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"status\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/challenge-request/:itemId";

    let payload = json!({"status": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/challenge-request/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "status": ""
}'
echo '{
  "status": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/challenge-request/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "status": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/challenge-request/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["status": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/challenge-request/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_Company_for_User
{{baseUrl}}/user/:userID/company
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
BODY json

{
  "address_main": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_postal": {},
  "avatar_uuid": "",
  "chamber_of_commerce_number": "",
  "country": "",
  "legal_form": "",
  "name": "",
  "signup_track_type": "",
  "subscription_type": "",
  "ubo": [
    {
      "date_of_birth": "",
      "name": "",
      "nationality": ""
    }
  ],
  "vat_number": {
    "country": "",
    "value": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/company");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"avatar_uuid\": \"\",\n  \"chamber_of_commerce_number\": \"\",\n  \"country\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"signup_track_type\": \"\",\n  \"subscription_type\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"vat_number\": {\n    \"country\": \"\",\n    \"value\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/company" {:headers {:user-agent ""
                                                                           :x-bunq-client-authentication ""}
                                                                 :content-type :json
                                                                 :form-params {:address_main {:city ""
                                                                                              :country ""
                                                                                              :extra ""
                                                                                              :house_number ""
                                                                                              :is_user_address_updated false
                                                                                              :mailbox_name ""
                                                                                              :po_box ""
                                                                                              :postal_code ""
                                                                                              :province ""
                                                                                              :street ""}
                                                                               :address_postal {}
                                                                               :avatar_uuid ""
                                                                               :chamber_of_commerce_number ""
                                                                               :country ""
                                                                               :legal_form ""
                                                                               :name ""
                                                                               :signup_track_type ""
                                                                               :subscription_type ""
                                                                               :ubo [{:date_of_birth ""
                                                                                      :name ""
                                                                                      :nationality ""}]
                                                                               :vat_number {:country ""
                                                                                            :value ""}}})
require "http/client"

url = "{{baseUrl}}/user/:userID/company"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"avatar_uuid\": \"\",\n  \"chamber_of_commerce_number\": \"\",\n  \"country\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"signup_track_type\": \"\",\n  \"subscription_type\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"vat_number\": {\n    \"country\": \"\",\n    \"value\": \"\"\n  }\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/company"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"avatar_uuid\": \"\",\n  \"chamber_of_commerce_number\": \"\",\n  \"country\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"signup_track_type\": \"\",\n  \"subscription_type\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"vat_number\": {\n    \"country\": \"\",\n    \"value\": \"\"\n  }\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/company");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"avatar_uuid\": \"\",\n  \"chamber_of_commerce_number\": \"\",\n  \"country\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"signup_track_type\": \"\",\n  \"subscription_type\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"vat_number\": {\n    \"country\": \"\",\n    \"value\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/company"

	payload := strings.NewReader("{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"avatar_uuid\": \"\",\n  \"chamber_of_commerce_number\": \"\",\n  \"country\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"signup_track_type\": \"\",\n  \"subscription_type\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"vat_number\": {\n    \"country\": \"\",\n    \"value\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/company HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 584

{
  "address_main": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_postal": {},
  "avatar_uuid": "",
  "chamber_of_commerce_number": "",
  "country": "",
  "legal_form": "",
  "name": "",
  "signup_track_type": "",
  "subscription_type": "",
  "ubo": [
    {
      "date_of_birth": "",
      "name": "",
      "nationality": ""
    }
  ],
  "vat_number": {
    "country": "",
    "value": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/company")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"avatar_uuid\": \"\",\n  \"chamber_of_commerce_number\": \"\",\n  \"country\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"signup_track_type\": \"\",\n  \"subscription_type\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"vat_number\": {\n    \"country\": \"\",\n    \"value\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/company"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"avatar_uuid\": \"\",\n  \"chamber_of_commerce_number\": \"\",\n  \"country\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"signup_track_type\": \"\",\n  \"subscription_type\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"vat_number\": {\n    \"country\": \"\",\n    \"value\": \"\"\n  }\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"avatar_uuid\": \"\",\n  \"chamber_of_commerce_number\": \"\",\n  \"country\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"signup_track_type\": \"\",\n  \"subscription_type\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"vat_number\": {\n    \"country\": \"\",\n    \"value\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/company")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/company")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"avatar_uuid\": \"\",\n  \"chamber_of_commerce_number\": \"\",\n  \"country\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"signup_track_type\": \"\",\n  \"subscription_type\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"vat_number\": {\n    \"country\": \"\",\n    \"value\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  address_main: {
    city: '',
    country: '',
    extra: '',
    house_number: '',
    is_user_address_updated: false,
    mailbox_name: '',
    po_box: '',
    postal_code: '',
    province: '',
    street: ''
  },
  address_postal: {},
  avatar_uuid: '',
  chamber_of_commerce_number: '',
  country: '',
  legal_form: '',
  name: '',
  signup_track_type: '',
  subscription_type: '',
  ubo: [
    {
      date_of_birth: '',
      name: '',
      nationality: ''
    }
  ],
  vat_number: {
    country: '',
    value: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/company');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/company',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    address_main: {
      city: '',
      country: '',
      extra: '',
      house_number: '',
      is_user_address_updated: false,
      mailbox_name: '',
      po_box: '',
      postal_code: '',
      province: '',
      street: ''
    },
    address_postal: {},
    avatar_uuid: '',
    chamber_of_commerce_number: '',
    country: '',
    legal_form: '',
    name: '',
    signup_track_type: '',
    subscription_type: '',
    ubo: [{date_of_birth: '', name: '', nationality: ''}],
    vat_number: {country: '', value: ''}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/company';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"address_main":{"city":"","country":"","extra":"","house_number":"","is_user_address_updated":false,"mailbox_name":"","po_box":"","postal_code":"","province":"","street":""},"address_postal":{},"avatar_uuid":"","chamber_of_commerce_number":"","country":"","legal_form":"","name":"","signup_track_type":"","subscription_type":"","ubo":[{"date_of_birth":"","name":"","nationality":""}],"vat_number":{"country":"","value":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/company',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "address_main": {\n    "city": "",\n    "country": "",\n    "extra": "",\n    "house_number": "",\n    "is_user_address_updated": false,\n    "mailbox_name": "",\n    "po_box": "",\n    "postal_code": "",\n    "province": "",\n    "street": ""\n  },\n  "address_postal": {},\n  "avatar_uuid": "",\n  "chamber_of_commerce_number": "",\n  "country": "",\n  "legal_form": "",\n  "name": "",\n  "signup_track_type": "",\n  "subscription_type": "",\n  "ubo": [\n    {\n      "date_of_birth": "",\n      "name": "",\n      "nationality": ""\n    }\n  ],\n  "vat_number": {\n    "country": "",\n    "value": ""\n  }\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"avatar_uuid\": \"\",\n  \"chamber_of_commerce_number\": \"\",\n  \"country\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"signup_track_type\": \"\",\n  \"subscription_type\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"vat_number\": {\n    \"country\": \"\",\n    \"value\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/company")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/company',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  address_main: {
    city: '',
    country: '',
    extra: '',
    house_number: '',
    is_user_address_updated: false,
    mailbox_name: '',
    po_box: '',
    postal_code: '',
    province: '',
    street: ''
  },
  address_postal: {},
  avatar_uuid: '',
  chamber_of_commerce_number: '',
  country: '',
  legal_form: '',
  name: '',
  signup_track_type: '',
  subscription_type: '',
  ubo: [{date_of_birth: '', name: '', nationality: ''}],
  vat_number: {country: '', value: ''}
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/company',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    address_main: {
      city: '',
      country: '',
      extra: '',
      house_number: '',
      is_user_address_updated: false,
      mailbox_name: '',
      po_box: '',
      postal_code: '',
      province: '',
      street: ''
    },
    address_postal: {},
    avatar_uuid: '',
    chamber_of_commerce_number: '',
    country: '',
    legal_form: '',
    name: '',
    signup_track_type: '',
    subscription_type: '',
    ubo: [{date_of_birth: '', name: '', nationality: ''}],
    vat_number: {country: '', value: ''}
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/company');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  address_main: {
    city: '',
    country: '',
    extra: '',
    house_number: '',
    is_user_address_updated: false,
    mailbox_name: '',
    po_box: '',
    postal_code: '',
    province: '',
    street: ''
  },
  address_postal: {},
  avatar_uuid: '',
  chamber_of_commerce_number: '',
  country: '',
  legal_form: '',
  name: '',
  signup_track_type: '',
  subscription_type: '',
  ubo: [
    {
      date_of_birth: '',
      name: '',
      nationality: ''
    }
  ],
  vat_number: {
    country: '',
    value: ''
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/company',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    address_main: {
      city: '',
      country: '',
      extra: '',
      house_number: '',
      is_user_address_updated: false,
      mailbox_name: '',
      po_box: '',
      postal_code: '',
      province: '',
      street: ''
    },
    address_postal: {},
    avatar_uuid: '',
    chamber_of_commerce_number: '',
    country: '',
    legal_form: '',
    name: '',
    signup_track_type: '',
    subscription_type: '',
    ubo: [{date_of_birth: '', name: '', nationality: ''}],
    vat_number: {country: '', value: ''}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/company';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"address_main":{"city":"","country":"","extra":"","house_number":"","is_user_address_updated":false,"mailbox_name":"","po_box":"","postal_code":"","province":"","street":""},"address_postal":{},"avatar_uuid":"","chamber_of_commerce_number":"","country":"","legal_form":"","name":"","signup_track_type":"","subscription_type":"","ubo":[{"date_of_birth":"","name":"","nationality":""}],"vat_number":{"country":"","value":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"address_main": @{ @"city": @"", @"country": @"", @"extra": @"", @"house_number": @"", @"is_user_address_updated": @NO, @"mailbox_name": @"", @"po_box": @"", @"postal_code": @"", @"province": @"", @"street": @"" },
                              @"address_postal": @{  },
                              @"avatar_uuid": @"",
                              @"chamber_of_commerce_number": @"",
                              @"country": @"",
                              @"legal_form": @"",
                              @"name": @"",
                              @"signup_track_type": @"",
                              @"subscription_type": @"",
                              @"ubo": @[ @{ @"date_of_birth": @"", @"name": @"", @"nationality": @"" } ],
                              @"vat_number": @{ @"country": @"", @"value": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/company"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/company" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"avatar_uuid\": \"\",\n  \"chamber_of_commerce_number\": \"\",\n  \"country\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"signup_track_type\": \"\",\n  \"subscription_type\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"vat_number\": {\n    \"country\": \"\",\n    \"value\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/company",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'address_main' => [
        'city' => '',
        'country' => '',
        'extra' => '',
        'house_number' => '',
        'is_user_address_updated' => null,
        'mailbox_name' => '',
        'po_box' => '',
        'postal_code' => '',
        'province' => '',
        'street' => ''
    ],
    'address_postal' => [
        
    ],
    'avatar_uuid' => '',
    'chamber_of_commerce_number' => '',
    'country' => '',
    'legal_form' => '',
    'name' => '',
    'signup_track_type' => '',
    'subscription_type' => '',
    'ubo' => [
        [
                'date_of_birth' => '',
                'name' => '',
                'nationality' => ''
        ]
    ],
    'vat_number' => [
        'country' => '',
        'value' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/company', [
  'body' => '{
  "address_main": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_postal": {},
  "avatar_uuid": "",
  "chamber_of_commerce_number": "",
  "country": "",
  "legal_form": "",
  "name": "",
  "signup_track_type": "",
  "subscription_type": "",
  "ubo": [
    {
      "date_of_birth": "",
      "name": "",
      "nationality": ""
    }
  ],
  "vat_number": {
    "country": "",
    "value": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/company');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'address_main' => [
    'city' => '',
    'country' => '',
    'extra' => '',
    'house_number' => '',
    'is_user_address_updated' => null,
    'mailbox_name' => '',
    'po_box' => '',
    'postal_code' => '',
    'province' => '',
    'street' => ''
  ],
  'address_postal' => [
    
  ],
  'avatar_uuid' => '',
  'chamber_of_commerce_number' => '',
  'country' => '',
  'legal_form' => '',
  'name' => '',
  'signup_track_type' => '',
  'subscription_type' => '',
  'ubo' => [
    [
        'date_of_birth' => '',
        'name' => '',
        'nationality' => ''
    ]
  ],
  'vat_number' => [
    'country' => '',
    'value' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'address_main' => [
    'city' => '',
    'country' => '',
    'extra' => '',
    'house_number' => '',
    'is_user_address_updated' => null,
    'mailbox_name' => '',
    'po_box' => '',
    'postal_code' => '',
    'province' => '',
    'street' => ''
  ],
  'address_postal' => [
    
  ],
  'avatar_uuid' => '',
  'chamber_of_commerce_number' => '',
  'country' => '',
  'legal_form' => '',
  'name' => '',
  'signup_track_type' => '',
  'subscription_type' => '',
  'ubo' => [
    [
        'date_of_birth' => '',
        'name' => '',
        'nationality' => ''
    ]
  ],
  'vat_number' => [
    'country' => '',
    'value' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/company');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/company' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "address_main": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_postal": {},
  "avatar_uuid": "",
  "chamber_of_commerce_number": "",
  "country": "",
  "legal_form": "",
  "name": "",
  "signup_track_type": "",
  "subscription_type": "",
  "ubo": [
    {
      "date_of_birth": "",
      "name": "",
      "nationality": ""
    }
  ],
  "vat_number": {
    "country": "",
    "value": ""
  }
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/company' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "address_main": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_postal": {},
  "avatar_uuid": "",
  "chamber_of_commerce_number": "",
  "country": "",
  "legal_form": "",
  "name": "",
  "signup_track_type": "",
  "subscription_type": "",
  "ubo": [
    {
      "date_of_birth": "",
      "name": "",
      "nationality": ""
    }
  ],
  "vat_number": {
    "country": "",
    "value": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"avatar_uuid\": \"\",\n  \"chamber_of_commerce_number\": \"\",\n  \"country\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"signup_track_type\": \"\",\n  \"subscription_type\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"vat_number\": {\n    \"country\": \"\",\n    \"value\": \"\"\n  }\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/company", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/company"

payload = {
    "address_main": {
        "city": "",
        "country": "",
        "extra": "",
        "house_number": "",
        "is_user_address_updated": False,
        "mailbox_name": "",
        "po_box": "",
        "postal_code": "",
        "province": "",
        "street": ""
    },
    "address_postal": {},
    "avatar_uuid": "",
    "chamber_of_commerce_number": "",
    "country": "",
    "legal_form": "",
    "name": "",
    "signup_track_type": "",
    "subscription_type": "",
    "ubo": [
        {
            "date_of_birth": "",
            "name": "",
            "nationality": ""
        }
    ],
    "vat_number": {
        "country": "",
        "value": ""
    }
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/company"

payload <- "{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"avatar_uuid\": \"\",\n  \"chamber_of_commerce_number\": \"\",\n  \"country\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"signup_track_type\": \"\",\n  \"subscription_type\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"vat_number\": {\n    \"country\": \"\",\n    \"value\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/company")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"avatar_uuid\": \"\",\n  \"chamber_of_commerce_number\": \"\",\n  \"country\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"signup_track_type\": \"\",\n  \"subscription_type\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"vat_number\": {\n    \"country\": \"\",\n    \"value\": \"\"\n  }\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/company') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"avatar_uuid\": \"\",\n  \"chamber_of_commerce_number\": \"\",\n  \"country\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"signup_track_type\": \"\",\n  \"subscription_type\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"vat_number\": {\n    \"country\": \"\",\n    \"value\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/company";

    let payload = json!({
        "address_main": json!({
            "city": "",
            "country": "",
            "extra": "",
            "house_number": "",
            "is_user_address_updated": false,
            "mailbox_name": "",
            "po_box": "",
            "postal_code": "",
            "province": "",
            "street": ""
        }),
        "address_postal": json!({}),
        "avatar_uuid": "",
        "chamber_of_commerce_number": "",
        "country": "",
        "legal_form": "",
        "name": "",
        "signup_track_type": "",
        "subscription_type": "",
        "ubo": (
            json!({
                "date_of_birth": "",
                "name": "",
                "nationality": ""
            })
        ),
        "vat_number": json!({
            "country": "",
            "value": ""
        })
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/company \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "address_main": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_postal": {},
  "avatar_uuid": "",
  "chamber_of_commerce_number": "",
  "country": "",
  "legal_form": "",
  "name": "",
  "signup_track_type": "",
  "subscription_type": "",
  "ubo": [
    {
      "date_of_birth": "",
      "name": "",
      "nationality": ""
    }
  ],
  "vat_number": {
    "country": "",
    "value": ""
  }
}'
echo '{
  "address_main": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_postal": {},
  "avatar_uuid": "",
  "chamber_of_commerce_number": "",
  "country": "",
  "legal_form": "",
  "name": "",
  "signup_track_type": "",
  "subscription_type": "",
  "ubo": [
    {
      "date_of_birth": "",
      "name": "",
      "nationality": ""
    }
  ],
  "vat_number": {
    "country": "",
    "value": ""
  }
}' |  \
  http POST {{baseUrl}}/user/:userID/company \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "address_main": {\n    "city": "",\n    "country": "",\n    "extra": "",\n    "house_number": "",\n    "is_user_address_updated": false,\n    "mailbox_name": "",\n    "po_box": "",\n    "postal_code": "",\n    "province": "",\n    "street": ""\n  },\n  "address_postal": {},\n  "avatar_uuid": "",\n  "chamber_of_commerce_number": "",\n  "country": "",\n  "legal_form": "",\n  "name": "",\n  "signup_track_type": "",\n  "subscription_type": "",\n  "ubo": [\n    {\n      "date_of_birth": "",\n      "name": "",\n      "nationality": ""\n    }\n  ],\n  "vat_number": {\n    "country": "",\n    "value": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/company
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "address_main": [
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  ],
  "address_postal": [],
  "avatar_uuid": "",
  "chamber_of_commerce_number": "",
  "country": "",
  "legal_form": "",
  "name": "",
  "signup_track_type": "",
  "subscription_type": "",
  "ubo": [
    [
      "date_of_birth": "",
      "name": "",
      "nationality": ""
    ]
  ],
  "vat_number": [
    "country": "",
    "value": ""
  ]
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/company")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_Company_for_User
{{baseUrl}}/user/:userID/company
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/company");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/company" {:headers {:user-agent ""
                                                                          :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/company"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/company"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/company");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/company"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/company HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/company")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/company"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/company")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/company")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/company');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/company',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/company';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/company',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/company")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/company',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/company',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/company');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/company',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/company';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/company"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/company" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/company",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/company', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/company');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/company');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/company' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/company' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/company", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/company"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/company"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/company")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/company') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/company";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/company \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/company \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/company
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/company")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_Company_for_User
{{baseUrl}}/user/:userID/company/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/company/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/company/:itemId" {:headers {:user-agent ""
                                                                                  :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/company/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/company/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/company/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/company/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/company/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/company/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/company/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/company/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/company/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/company/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/company/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/company/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/company/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/company/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/company/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/company/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/company/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/company/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/company/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/company/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/company/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/company/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/company/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/company/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/company/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/company/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/company/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/company/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/company/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/company/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/company/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/company/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/company/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/company/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/company/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/company/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/company/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_Company_for_User
{{baseUrl}}/user/:userID/company/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
BODY json

{
  "address_main": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_postal": {},
  "avatar_uuid": "",
  "chamber_of_commerce_number": "",
  "country": "",
  "legal_form": "",
  "name": "",
  "signup_track_type": "",
  "subscription_type": "",
  "ubo": [
    {
      "date_of_birth": "",
      "name": "",
      "nationality": ""
    }
  ],
  "vat_number": {
    "country": "",
    "value": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/company/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"avatar_uuid\": \"\",\n  \"chamber_of_commerce_number\": \"\",\n  \"country\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"signup_track_type\": \"\",\n  \"subscription_type\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"vat_number\": {\n    \"country\": \"\",\n    \"value\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/company/:itemId" {:headers {:user-agent ""
                                                                                  :x-bunq-client-authentication ""}
                                                                        :content-type :json
                                                                        :form-params {:address_main {:city ""
                                                                                                     :country ""
                                                                                                     :extra ""
                                                                                                     :house_number ""
                                                                                                     :is_user_address_updated false
                                                                                                     :mailbox_name ""
                                                                                                     :po_box ""
                                                                                                     :postal_code ""
                                                                                                     :province ""
                                                                                                     :street ""}
                                                                                      :address_postal {}
                                                                                      :avatar_uuid ""
                                                                                      :chamber_of_commerce_number ""
                                                                                      :country ""
                                                                                      :legal_form ""
                                                                                      :name ""
                                                                                      :signup_track_type ""
                                                                                      :subscription_type ""
                                                                                      :ubo [{:date_of_birth ""
                                                                                             :name ""
                                                                                             :nationality ""}]
                                                                                      :vat_number {:country ""
                                                                                                   :value ""}}})
require "http/client"

url = "{{baseUrl}}/user/:userID/company/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"avatar_uuid\": \"\",\n  \"chamber_of_commerce_number\": \"\",\n  \"country\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"signup_track_type\": \"\",\n  \"subscription_type\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"vat_number\": {\n    \"country\": \"\",\n    \"value\": \"\"\n  }\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/company/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"avatar_uuid\": \"\",\n  \"chamber_of_commerce_number\": \"\",\n  \"country\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"signup_track_type\": \"\",\n  \"subscription_type\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"vat_number\": {\n    \"country\": \"\",\n    \"value\": \"\"\n  }\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/company/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"avatar_uuid\": \"\",\n  \"chamber_of_commerce_number\": \"\",\n  \"country\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"signup_track_type\": \"\",\n  \"subscription_type\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"vat_number\": {\n    \"country\": \"\",\n    \"value\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/company/:itemId"

	payload := strings.NewReader("{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"avatar_uuid\": \"\",\n  \"chamber_of_commerce_number\": \"\",\n  \"country\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"signup_track_type\": \"\",\n  \"subscription_type\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"vat_number\": {\n    \"country\": \"\",\n    \"value\": \"\"\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/company/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 584

{
  "address_main": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_postal": {},
  "avatar_uuid": "",
  "chamber_of_commerce_number": "",
  "country": "",
  "legal_form": "",
  "name": "",
  "signup_track_type": "",
  "subscription_type": "",
  "ubo": [
    {
      "date_of_birth": "",
      "name": "",
      "nationality": ""
    }
  ],
  "vat_number": {
    "country": "",
    "value": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/company/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"avatar_uuid\": \"\",\n  \"chamber_of_commerce_number\": \"\",\n  \"country\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"signup_track_type\": \"\",\n  \"subscription_type\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"vat_number\": {\n    \"country\": \"\",\n    \"value\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/company/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"avatar_uuid\": \"\",\n  \"chamber_of_commerce_number\": \"\",\n  \"country\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"signup_track_type\": \"\",\n  \"subscription_type\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"vat_number\": {\n    \"country\": \"\",\n    \"value\": \"\"\n  }\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"avatar_uuid\": \"\",\n  \"chamber_of_commerce_number\": \"\",\n  \"country\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"signup_track_type\": \"\",\n  \"subscription_type\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"vat_number\": {\n    \"country\": \"\",\n    \"value\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/company/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/company/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"avatar_uuid\": \"\",\n  \"chamber_of_commerce_number\": \"\",\n  \"country\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"signup_track_type\": \"\",\n  \"subscription_type\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"vat_number\": {\n    \"country\": \"\",\n    \"value\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  address_main: {
    city: '',
    country: '',
    extra: '',
    house_number: '',
    is_user_address_updated: false,
    mailbox_name: '',
    po_box: '',
    postal_code: '',
    province: '',
    street: ''
  },
  address_postal: {},
  avatar_uuid: '',
  chamber_of_commerce_number: '',
  country: '',
  legal_form: '',
  name: '',
  signup_track_type: '',
  subscription_type: '',
  ubo: [
    {
      date_of_birth: '',
      name: '',
      nationality: ''
    }
  ],
  vat_number: {
    country: '',
    value: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/company/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/company/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    address_main: {
      city: '',
      country: '',
      extra: '',
      house_number: '',
      is_user_address_updated: false,
      mailbox_name: '',
      po_box: '',
      postal_code: '',
      province: '',
      street: ''
    },
    address_postal: {},
    avatar_uuid: '',
    chamber_of_commerce_number: '',
    country: '',
    legal_form: '',
    name: '',
    signup_track_type: '',
    subscription_type: '',
    ubo: [{date_of_birth: '', name: '', nationality: ''}],
    vat_number: {country: '', value: ''}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/company/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"address_main":{"city":"","country":"","extra":"","house_number":"","is_user_address_updated":false,"mailbox_name":"","po_box":"","postal_code":"","province":"","street":""},"address_postal":{},"avatar_uuid":"","chamber_of_commerce_number":"","country":"","legal_form":"","name":"","signup_track_type":"","subscription_type":"","ubo":[{"date_of_birth":"","name":"","nationality":""}],"vat_number":{"country":"","value":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/company/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "address_main": {\n    "city": "",\n    "country": "",\n    "extra": "",\n    "house_number": "",\n    "is_user_address_updated": false,\n    "mailbox_name": "",\n    "po_box": "",\n    "postal_code": "",\n    "province": "",\n    "street": ""\n  },\n  "address_postal": {},\n  "avatar_uuid": "",\n  "chamber_of_commerce_number": "",\n  "country": "",\n  "legal_form": "",\n  "name": "",\n  "signup_track_type": "",\n  "subscription_type": "",\n  "ubo": [\n    {\n      "date_of_birth": "",\n      "name": "",\n      "nationality": ""\n    }\n  ],\n  "vat_number": {\n    "country": "",\n    "value": ""\n  }\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"avatar_uuid\": \"\",\n  \"chamber_of_commerce_number\": \"\",\n  \"country\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"signup_track_type\": \"\",\n  \"subscription_type\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"vat_number\": {\n    \"country\": \"\",\n    \"value\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/company/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/company/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  address_main: {
    city: '',
    country: '',
    extra: '',
    house_number: '',
    is_user_address_updated: false,
    mailbox_name: '',
    po_box: '',
    postal_code: '',
    province: '',
    street: ''
  },
  address_postal: {},
  avatar_uuid: '',
  chamber_of_commerce_number: '',
  country: '',
  legal_form: '',
  name: '',
  signup_track_type: '',
  subscription_type: '',
  ubo: [{date_of_birth: '', name: '', nationality: ''}],
  vat_number: {country: '', value: ''}
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/company/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    address_main: {
      city: '',
      country: '',
      extra: '',
      house_number: '',
      is_user_address_updated: false,
      mailbox_name: '',
      po_box: '',
      postal_code: '',
      province: '',
      street: ''
    },
    address_postal: {},
    avatar_uuid: '',
    chamber_of_commerce_number: '',
    country: '',
    legal_form: '',
    name: '',
    signup_track_type: '',
    subscription_type: '',
    ubo: [{date_of_birth: '', name: '', nationality: ''}],
    vat_number: {country: '', value: ''}
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/company/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  address_main: {
    city: '',
    country: '',
    extra: '',
    house_number: '',
    is_user_address_updated: false,
    mailbox_name: '',
    po_box: '',
    postal_code: '',
    province: '',
    street: ''
  },
  address_postal: {},
  avatar_uuid: '',
  chamber_of_commerce_number: '',
  country: '',
  legal_form: '',
  name: '',
  signup_track_type: '',
  subscription_type: '',
  ubo: [
    {
      date_of_birth: '',
      name: '',
      nationality: ''
    }
  ],
  vat_number: {
    country: '',
    value: ''
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/company/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    address_main: {
      city: '',
      country: '',
      extra: '',
      house_number: '',
      is_user_address_updated: false,
      mailbox_name: '',
      po_box: '',
      postal_code: '',
      province: '',
      street: ''
    },
    address_postal: {},
    avatar_uuid: '',
    chamber_of_commerce_number: '',
    country: '',
    legal_form: '',
    name: '',
    signup_track_type: '',
    subscription_type: '',
    ubo: [{date_of_birth: '', name: '', nationality: ''}],
    vat_number: {country: '', value: ''}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/company/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"address_main":{"city":"","country":"","extra":"","house_number":"","is_user_address_updated":false,"mailbox_name":"","po_box":"","postal_code":"","province":"","street":""},"address_postal":{},"avatar_uuid":"","chamber_of_commerce_number":"","country":"","legal_form":"","name":"","signup_track_type":"","subscription_type":"","ubo":[{"date_of_birth":"","name":"","nationality":""}],"vat_number":{"country":"","value":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"address_main": @{ @"city": @"", @"country": @"", @"extra": @"", @"house_number": @"", @"is_user_address_updated": @NO, @"mailbox_name": @"", @"po_box": @"", @"postal_code": @"", @"province": @"", @"street": @"" },
                              @"address_postal": @{  },
                              @"avatar_uuid": @"",
                              @"chamber_of_commerce_number": @"",
                              @"country": @"",
                              @"legal_form": @"",
                              @"name": @"",
                              @"signup_track_type": @"",
                              @"subscription_type": @"",
                              @"ubo": @[ @{ @"date_of_birth": @"", @"name": @"", @"nationality": @"" } ],
                              @"vat_number": @{ @"country": @"", @"value": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/company/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/company/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"avatar_uuid\": \"\",\n  \"chamber_of_commerce_number\": \"\",\n  \"country\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"signup_track_type\": \"\",\n  \"subscription_type\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"vat_number\": {\n    \"country\": \"\",\n    \"value\": \"\"\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/company/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'address_main' => [
        'city' => '',
        'country' => '',
        'extra' => '',
        'house_number' => '',
        'is_user_address_updated' => null,
        'mailbox_name' => '',
        'po_box' => '',
        'postal_code' => '',
        'province' => '',
        'street' => ''
    ],
    'address_postal' => [
        
    ],
    'avatar_uuid' => '',
    'chamber_of_commerce_number' => '',
    'country' => '',
    'legal_form' => '',
    'name' => '',
    'signup_track_type' => '',
    'subscription_type' => '',
    'ubo' => [
        [
                'date_of_birth' => '',
                'name' => '',
                'nationality' => ''
        ]
    ],
    'vat_number' => [
        'country' => '',
        'value' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/company/:itemId', [
  'body' => '{
  "address_main": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_postal": {},
  "avatar_uuid": "",
  "chamber_of_commerce_number": "",
  "country": "",
  "legal_form": "",
  "name": "",
  "signup_track_type": "",
  "subscription_type": "",
  "ubo": [
    {
      "date_of_birth": "",
      "name": "",
      "nationality": ""
    }
  ],
  "vat_number": {
    "country": "",
    "value": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/company/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'address_main' => [
    'city' => '',
    'country' => '',
    'extra' => '',
    'house_number' => '',
    'is_user_address_updated' => null,
    'mailbox_name' => '',
    'po_box' => '',
    'postal_code' => '',
    'province' => '',
    'street' => ''
  ],
  'address_postal' => [
    
  ],
  'avatar_uuid' => '',
  'chamber_of_commerce_number' => '',
  'country' => '',
  'legal_form' => '',
  'name' => '',
  'signup_track_type' => '',
  'subscription_type' => '',
  'ubo' => [
    [
        'date_of_birth' => '',
        'name' => '',
        'nationality' => ''
    ]
  ],
  'vat_number' => [
    'country' => '',
    'value' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'address_main' => [
    'city' => '',
    'country' => '',
    'extra' => '',
    'house_number' => '',
    'is_user_address_updated' => null,
    'mailbox_name' => '',
    'po_box' => '',
    'postal_code' => '',
    'province' => '',
    'street' => ''
  ],
  'address_postal' => [
    
  ],
  'avatar_uuid' => '',
  'chamber_of_commerce_number' => '',
  'country' => '',
  'legal_form' => '',
  'name' => '',
  'signup_track_type' => '',
  'subscription_type' => '',
  'ubo' => [
    [
        'date_of_birth' => '',
        'name' => '',
        'nationality' => ''
    ]
  ],
  'vat_number' => [
    'country' => '',
    'value' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/company/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/company/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "address_main": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_postal": {},
  "avatar_uuid": "",
  "chamber_of_commerce_number": "",
  "country": "",
  "legal_form": "",
  "name": "",
  "signup_track_type": "",
  "subscription_type": "",
  "ubo": [
    {
      "date_of_birth": "",
      "name": "",
      "nationality": ""
    }
  ],
  "vat_number": {
    "country": "",
    "value": ""
  }
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/company/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "address_main": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_postal": {},
  "avatar_uuid": "",
  "chamber_of_commerce_number": "",
  "country": "",
  "legal_form": "",
  "name": "",
  "signup_track_type": "",
  "subscription_type": "",
  "ubo": [
    {
      "date_of_birth": "",
      "name": "",
      "nationality": ""
    }
  ],
  "vat_number": {
    "country": "",
    "value": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"avatar_uuid\": \"\",\n  \"chamber_of_commerce_number\": \"\",\n  \"country\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"signup_track_type\": \"\",\n  \"subscription_type\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"vat_number\": {\n    \"country\": \"\",\n    \"value\": \"\"\n  }\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/company/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/company/:itemId"

payload = {
    "address_main": {
        "city": "",
        "country": "",
        "extra": "",
        "house_number": "",
        "is_user_address_updated": False,
        "mailbox_name": "",
        "po_box": "",
        "postal_code": "",
        "province": "",
        "street": ""
    },
    "address_postal": {},
    "avatar_uuid": "",
    "chamber_of_commerce_number": "",
    "country": "",
    "legal_form": "",
    "name": "",
    "signup_track_type": "",
    "subscription_type": "",
    "ubo": [
        {
            "date_of_birth": "",
            "name": "",
            "nationality": ""
        }
    ],
    "vat_number": {
        "country": "",
        "value": ""
    }
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/company/:itemId"

payload <- "{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"avatar_uuid\": \"\",\n  \"chamber_of_commerce_number\": \"\",\n  \"country\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"signup_track_type\": \"\",\n  \"subscription_type\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"vat_number\": {\n    \"country\": \"\",\n    \"value\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/company/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"avatar_uuid\": \"\",\n  \"chamber_of_commerce_number\": \"\",\n  \"country\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"signup_track_type\": \"\",\n  \"subscription_type\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"vat_number\": {\n    \"country\": \"\",\n    \"value\": \"\"\n  }\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/company/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"avatar_uuid\": \"\",\n  \"chamber_of_commerce_number\": \"\",\n  \"country\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"signup_track_type\": \"\",\n  \"subscription_type\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"vat_number\": {\n    \"country\": \"\",\n    \"value\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/company/:itemId";

    let payload = json!({
        "address_main": json!({
            "city": "",
            "country": "",
            "extra": "",
            "house_number": "",
            "is_user_address_updated": false,
            "mailbox_name": "",
            "po_box": "",
            "postal_code": "",
            "province": "",
            "street": ""
        }),
        "address_postal": json!({}),
        "avatar_uuid": "",
        "chamber_of_commerce_number": "",
        "country": "",
        "legal_form": "",
        "name": "",
        "signup_track_type": "",
        "subscription_type": "",
        "ubo": (
            json!({
                "date_of_birth": "",
                "name": "",
                "nationality": ""
            })
        ),
        "vat_number": json!({
            "country": "",
            "value": ""
        })
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/company/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "address_main": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_postal": {},
  "avatar_uuid": "",
  "chamber_of_commerce_number": "",
  "country": "",
  "legal_form": "",
  "name": "",
  "signup_track_type": "",
  "subscription_type": "",
  "ubo": [
    {
      "date_of_birth": "",
      "name": "",
      "nationality": ""
    }
  ],
  "vat_number": {
    "country": "",
    "value": ""
  }
}'
echo '{
  "address_main": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_postal": {},
  "avatar_uuid": "",
  "chamber_of_commerce_number": "",
  "country": "",
  "legal_form": "",
  "name": "",
  "signup_track_type": "",
  "subscription_type": "",
  "ubo": [
    {
      "date_of_birth": "",
      "name": "",
      "nationality": ""
    }
  ],
  "vat_number": {
    "country": "",
    "value": ""
  }
}' |  \
  http PUT {{baseUrl}}/user/:userID/company/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "address_main": {\n    "city": "",\n    "country": "",\n    "extra": "",\n    "house_number": "",\n    "is_user_address_updated": false,\n    "mailbox_name": "",\n    "po_box": "",\n    "postal_code": "",\n    "province": "",\n    "street": ""\n  },\n  "address_postal": {},\n  "avatar_uuid": "",\n  "chamber_of_commerce_number": "",\n  "country": "",\n  "legal_form": "",\n  "name": "",\n  "signup_track_type": "",\n  "subscription_type": "",\n  "ubo": [\n    {\n      "date_of_birth": "",\n      "name": "",\n      "nationality": ""\n    }\n  ],\n  "vat_number": {\n    "country": "",\n    "value": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/company/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "address_main": [
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  ],
  "address_postal": [],
  "avatar_uuid": "",
  "chamber_of_commerce_number": "",
  "country": "",
  "legal_form": "",
  "name": "",
  "signup_track_type": "",
  "subscription_type": "",
  "ubo": [
    [
      "date_of_birth": "",
      "name": "",
      "nationality": ""
    ]
  ],
  "vat_number": [
    "country": "",
    "value": ""
  ]
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/company/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_ConfirmationOfFunds_for_User
{{baseUrl}}/user/:userID/confirmation-of-funds
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
BODY json

{
  "amount": {
    "currency": "",
    "value": ""
  },
  "pointer_iban": {
    "name": "",
    "service": "",
    "type": "",
    "value": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/confirmation-of-funds");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"pointer_iban\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/confirmation-of-funds" {:headers {:user-agent ""
                                                                                         :x-bunq-client-authentication ""}
                                                                               :content-type :json
                                                                               :form-params {:amount {:currency ""
                                                                                                      :value ""}
                                                                                             :pointer_iban {:name ""
                                                                                                            :service ""
                                                                                                            :type ""
                                                                                                            :value ""}}})
require "http/client"

url = "{{baseUrl}}/user/:userID/confirmation-of-funds"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"pointer_iban\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  }\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/confirmation-of-funds"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"pointer_iban\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  }\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/confirmation-of-funds");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"pointer_iban\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/confirmation-of-funds"

	payload := strings.NewReader("{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"pointer_iban\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/confirmation-of-funds HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 149

{
  "amount": {
    "currency": "",
    "value": ""
  },
  "pointer_iban": {
    "name": "",
    "service": "",
    "type": "",
    "value": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/confirmation-of-funds")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"pointer_iban\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/confirmation-of-funds"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"pointer_iban\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  }\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"pointer_iban\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/confirmation-of-funds")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/confirmation-of-funds")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"pointer_iban\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  amount: {
    currency: '',
    value: ''
  },
  pointer_iban: {
    name: '',
    service: '',
    type: '',
    value: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/confirmation-of-funds');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/confirmation-of-funds',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    amount: {currency: '', value: ''},
    pointer_iban: {name: '', service: '', type: '', value: ''}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/confirmation-of-funds';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"amount":{"currency":"","value":""},"pointer_iban":{"name":"","service":"","type":"","value":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/confirmation-of-funds',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "amount": {\n    "currency": "",\n    "value": ""\n  },\n  "pointer_iban": {\n    "name": "",\n    "service": "",\n    "type": "",\n    "value": ""\n  }\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"pointer_iban\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/confirmation-of-funds")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/confirmation-of-funds',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  amount: {currency: '', value: ''},
  pointer_iban: {name: '', service: '', type: '', value: ''}
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/confirmation-of-funds',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    amount: {currency: '', value: ''},
    pointer_iban: {name: '', service: '', type: '', value: ''}
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/confirmation-of-funds');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  amount: {
    currency: '',
    value: ''
  },
  pointer_iban: {
    name: '',
    service: '',
    type: '',
    value: ''
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/confirmation-of-funds',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    amount: {currency: '', value: ''},
    pointer_iban: {name: '', service: '', type: '', value: ''}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/confirmation-of-funds';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"amount":{"currency":"","value":""},"pointer_iban":{"name":"","service":"","type":"","value":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"amount": @{ @"currency": @"", @"value": @"" },
                              @"pointer_iban": @{ @"name": @"", @"service": @"", @"type": @"", @"value": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/confirmation-of-funds"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/confirmation-of-funds" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"pointer_iban\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/confirmation-of-funds",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'amount' => [
        'currency' => '',
        'value' => ''
    ],
    'pointer_iban' => [
        'name' => '',
        'service' => '',
        'type' => '',
        'value' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/confirmation-of-funds', [
  'body' => '{
  "amount": {
    "currency": "",
    "value": ""
  },
  "pointer_iban": {
    "name": "",
    "service": "",
    "type": "",
    "value": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/confirmation-of-funds');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'amount' => [
    'currency' => '',
    'value' => ''
  ],
  'pointer_iban' => [
    'name' => '',
    'service' => '',
    'type' => '',
    'value' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'amount' => [
    'currency' => '',
    'value' => ''
  ],
  'pointer_iban' => [
    'name' => '',
    'service' => '',
    'type' => '',
    'value' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/confirmation-of-funds');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/confirmation-of-funds' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "amount": {
    "currency": "",
    "value": ""
  },
  "pointer_iban": {
    "name": "",
    "service": "",
    "type": "",
    "value": ""
  }
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/confirmation-of-funds' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "amount": {
    "currency": "",
    "value": ""
  },
  "pointer_iban": {
    "name": "",
    "service": "",
    "type": "",
    "value": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"pointer_iban\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  }\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/confirmation-of-funds", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/confirmation-of-funds"

payload = {
    "amount": {
        "currency": "",
        "value": ""
    },
    "pointer_iban": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
    }
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/confirmation-of-funds"

payload <- "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"pointer_iban\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/confirmation-of-funds")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"pointer_iban\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  }\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/confirmation-of-funds') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"pointer_iban\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/confirmation-of-funds";

    let payload = json!({
        "amount": json!({
            "currency": "",
            "value": ""
        }),
        "pointer_iban": json!({
            "name": "",
            "service": "",
            "type": "",
            "value": ""
        })
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/confirmation-of-funds \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "amount": {
    "currency": "",
    "value": ""
  },
  "pointer_iban": {
    "name": "",
    "service": "",
    "type": "",
    "value": ""
  }
}'
echo '{
  "amount": {
    "currency": "",
    "value": ""
  },
  "pointer_iban": {
    "name": "",
    "service": "",
    "type": "",
    "value": ""
  }
}' |  \
  http POST {{baseUrl}}/user/:userID/confirmation-of-funds \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "amount": {\n    "currency": "",\n    "value": ""\n  },\n  "pointer_iban": {\n    "name": "",\n    "service": "",\n    "type": "",\n    "value": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/confirmation-of-funds
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "amount": [
    "currency": "",
    "value": ""
  ],
  "pointer_iban": [
    "name": "",
    "service": "",
    "type": "",
    "value": ""
  ]
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/confirmation-of-funds")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_Content_for_AttachmentPublic
{{baseUrl}}/attachment-public/:attachment-publicUUID/content
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

attachment-publicUUID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/attachment-public/:attachment-publicUUID/content");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/attachment-public/:attachment-publicUUID/content" {:headers {:user-agent ""
                                                                                                      :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/attachment-public/:attachment-publicUUID/content"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/attachment-public/:attachment-publicUUID/content"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/attachment-public/:attachment-publicUUID/content");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/attachment-public/:attachment-publicUUID/content"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/attachment-public/:attachment-publicUUID/content HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/attachment-public/:attachment-publicUUID/content")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/attachment-public/:attachment-publicUUID/content"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/attachment-public/:attachment-publicUUID/content")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/attachment-public/:attachment-publicUUID/content")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/attachment-public/:attachment-publicUUID/content');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/attachment-public/:attachment-publicUUID/content',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/attachment-public/:attachment-publicUUID/content';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/attachment-public/:attachment-publicUUID/content',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/attachment-public/:attachment-publicUUID/content")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/attachment-public/:attachment-publicUUID/content',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/attachment-public/:attachment-publicUUID/content',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/attachment-public/:attachment-publicUUID/content');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/attachment-public/:attachment-publicUUID/content',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/attachment-public/:attachment-publicUUID/content';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/attachment-public/:attachment-publicUUID/content"]
                                                       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}}/attachment-public/:attachment-publicUUID/content" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/attachment-public/:attachment-publicUUID/content",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/attachment-public/:attachment-publicUUID/content', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/attachment-public/:attachment-publicUUID/content');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/attachment-public/:attachment-publicUUID/content');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/attachment-public/:attachment-publicUUID/content' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/attachment-public/:attachment-publicUUID/content' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/attachment-public/:attachment-publicUUID/content", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/attachment-public/:attachment-publicUUID/content"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/attachment-public/:attachment-publicUUID/content"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/attachment-public/:attachment-publicUUID/content")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/attachment-public/:attachment-publicUUID/content') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/attachment-public/:attachment-publicUUID/content";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".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}}/attachment-public/:attachment-publicUUID/content \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/attachment-public/:attachment-publicUUID/content \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/attachment-public/:attachment-publicUUID/content
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/attachment-public/:attachment-publicUUID/content")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_Content_for_PlaceLookup_Photo
{{baseUrl}}/place-lookup/:place-lookupID/photo/:photoID/content
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

place-lookupID
photoID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/place-lookup/:place-lookupID/photo/:photoID/content");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/place-lookup/:place-lookupID/photo/:photoID/content" {:headers {:user-agent ""
                                                                                                         :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/place-lookup/:place-lookupID/photo/:photoID/content"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/place-lookup/:place-lookupID/photo/:photoID/content"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/place-lookup/:place-lookupID/photo/:photoID/content");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/place-lookup/:place-lookupID/photo/:photoID/content"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/place-lookup/:place-lookupID/photo/:photoID/content HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/place-lookup/:place-lookupID/photo/:photoID/content")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/place-lookup/:place-lookupID/photo/:photoID/content"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/place-lookup/:place-lookupID/photo/:photoID/content")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/place-lookup/:place-lookupID/photo/:photoID/content")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/place-lookup/:place-lookupID/photo/:photoID/content');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/place-lookup/:place-lookupID/photo/:photoID/content',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/place-lookup/:place-lookupID/photo/:photoID/content';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/place-lookup/:place-lookupID/photo/:photoID/content',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/place-lookup/:place-lookupID/photo/:photoID/content")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/place-lookup/:place-lookupID/photo/:photoID/content',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/place-lookup/:place-lookupID/photo/:photoID/content',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/place-lookup/:place-lookupID/photo/:photoID/content');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/place-lookup/:place-lookupID/photo/:photoID/content',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/place-lookup/:place-lookupID/photo/:photoID/content';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/place-lookup/:place-lookupID/photo/:photoID/content"]
                                                       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}}/place-lookup/:place-lookupID/photo/:photoID/content" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/place-lookup/:place-lookupID/photo/:photoID/content",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/place-lookup/:place-lookupID/photo/:photoID/content', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/place-lookup/:place-lookupID/photo/:photoID/content');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/place-lookup/:place-lookupID/photo/:photoID/content');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/place-lookup/:place-lookupID/photo/:photoID/content' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/place-lookup/:place-lookupID/photo/:photoID/content' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/place-lookup/:place-lookupID/photo/:photoID/content", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/place-lookup/:place-lookupID/photo/:photoID/content"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/place-lookup/:place-lookupID/photo/:photoID/content"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/place-lookup/:place-lookupID/photo/:photoID/content")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/place-lookup/:place-lookupID/photo/:photoID/content') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/place-lookup/:place-lookupID/photo/:photoID/content";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".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}}/place-lookup/:place-lookupID/photo/:photoID/content \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/place-lookup/:place-lookupID/photo/:photoID/content \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/place-lookup/:place-lookupID/photo/:photoID/content
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/place-lookup/:place-lookupID/photo/:photoID/content")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_Content_for_User_Attachment
{{baseUrl}}/user/:userID/attachment/:attachmentID/content
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
attachmentID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/attachment/:attachmentID/content");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/attachment/:attachmentID/content" {:headers {:user-agent ""
                                                                                                   :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/attachment/:attachmentID/content"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/attachment/:attachmentID/content"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/attachment/:attachmentID/content");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/attachment/:attachmentID/content"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/attachment/:attachmentID/content HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/attachment/:attachmentID/content")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/attachment/:attachmentID/content"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/attachment/:attachmentID/content")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/attachment/:attachmentID/content")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/attachment/:attachmentID/content');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/attachment/:attachmentID/content',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/attachment/:attachmentID/content';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/attachment/:attachmentID/content',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/attachment/:attachmentID/content")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/attachment/:attachmentID/content',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/attachment/:attachmentID/content',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/attachment/:attachmentID/content');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/attachment/:attachmentID/content',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/attachment/:attachmentID/content';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/attachment/:attachmentID/content"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/attachment/:attachmentID/content" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/attachment/:attachmentID/content",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/attachment/:attachmentID/content', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/attachment/:attachmentID/content');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/attachment/:attachmentID/content');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/attachment/:attachmentID/content' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/attachment/:attachmentID/content' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/attachment/:attachmentID/content", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/attachment/:attachmentID/content"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/attachment/:attachmentID/content"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/attachment/:attachmentID/content")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/attachment/:attachmentID/content') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/attachment/:attachmentID/content";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/attachment/:attachmentID/content \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/attachment/:attachmentID/content \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/attachment/:attachmentID/content
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/attachment/:attachmentID/content")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_Content_for_User_Card_ExportStatementCard
{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:export-statement-cardID/content
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
cardID
export-statement-cardID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:export-statement-cardID/content");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:export-statement-cardID/content" {:headers {:user-agent ""
                                                                                                                                      :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:export-statement-cardID/content"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:export-statement-cardID/content"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:export-statement-cardID/content");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:export-statement-cardID/content"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/card/:cardID/export-statement-card/:export-statement-cardID/content HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:export-statement-cardID/content")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:export-statement-cardID/content"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:export-statement-cardID/content")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:export-statement-cardID/content")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:export-statement-cardID/content');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:export-statement-cardID/content',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:export-statement-cardID/content';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:export-statement-cardID/content',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:export-statement-cardID/content")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/card/:cardID/export-statement-card/:export-statement-cardID/content',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:export-statement-cardID/content',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:export-statement-cardID/content');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:export-statement-cardID/content',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:export-statement-cardID/content';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:export-statement-cardID/content"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:export-statement-cardID/content" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:export-statement-cardID/content",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:export-statement-cardID/content', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:export-statement-cardID/content');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:export-statement-cardID/content');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:export-statement-cardID/content' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:export-statement-cardID/content' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/card/:cardID/export-statement-card/:export-statement-cardID/content", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:export-statement-cardID/content"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:export-statement-cardID/content"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:export-statement-cardID/content")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/card/:cardID/export-statement-card/:export-statement-cardID/content') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:export-statement-cardID/content";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:export-statement-cardID/content \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:export-statement-cardID/content \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:export-statement-cardID/content
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:export-statement-cardID/content")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_Content_for_User_ChatConversation_Attachment
{{baseUrl}}/user/:userID/chat-conversation/:chat-conversationID/attachment/:attachmentID/content
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
chat-conversationID
attachmentID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/chat-conversation/:chat-conversationID/attachment/:attachmentID/content");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/chat-conversation/:chat-conversationID/attachment/:attachmentID/content" {:headers {:user-agent ""
                                                                                                                                          :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/chat-conversation/:chat-conversationID/attachment/:attachmentID/content"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/chat-conversation/:chat-conversationID/attachment/:attachmentID/content"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/chat-conversation/:chat-conversationID/attachment/:attachmentID/content");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/chat-conversation/:chat-conversationID/attachment/:attachmentID/content"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/chat-conversation/:chat-conversationID/attachment/:attachmentID/content HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/chat-conversation/:chat-conversationID/attachment/:attachmentID/content")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/chat-conversation/:chat-conversationID/attachment/:attachmentID/content"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/chat-conversation/:chat-conversationID/attachment/:attachmentID/content")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/chat-conversation/:chat-conversationID/attachment/:attachmentID/content")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/chat-conversation/:chat-conversationID/attachment/:attachmentID/content');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/chat-conversation/:chat-conversationID/attachment/:attachmentID/content',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/chat-conversation/:chat-conversationID/attachment/:attachmentID/content';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/chat-conversation/:chat-conversationID/attachment/:attachmentID/content',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/chat-conversation/:chat-conversationID/attachment/:attachmentID/content")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/chat-conversation/:chat-conversationID/attachment/:attachmentID/content',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/chat-conversation/:chat-conversationID/attachment/:attachmentID/content',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/chat-conversation/:chat-conversationID/attachment/:attachmentID/content');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/chat-conversation/:chat-conversationID/attachment/:attachmentID/content',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/chat-conversation/:chat-conversationID/attachment/:attachmentID/content';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/chat-conversation/:chat-conversationID/attachment/:attachmentID/content"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/chat-conversation/:chat-conversationID/attachment/:attachmentID/content" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/chat-conversation/:chat-conversationID/attachment/:attachmentID/content",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/chat-conversation/:chat-conversationID/attachment/:attachmentID/content', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/chat-conversation/:chat-conversationID/attachment/:attachmentID/content');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/chat-conversation/:chat-conversationID/attachment/:attachmentID/content');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/chat-conversation/:chat-conversationID/attachment/:attachmentID/content' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/chat-conversation/:chat-conversationID/attachment/:attachmentID/content' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/chat-conversation/:chat-conversationID/attachment/:attachmentID/content", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/chat-conversation/:chat-conversationID/attachment/:attachmentID/content"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/chat-conversation/:chat-conversationID/attachment/:attachmentID/content"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/chat-conversation/:chat-conversationID/attachment/:attachmentID/content")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/chat-conversation/:chat-conversationID/attachment/:attachmentID/content') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/chat-conversation/:chat-conversationID/attachment/:attachmentID/content";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/chat-conversation/:chat-conversationID/attachment/:attachmentID/content \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/chat-conversation/:chat-conversationID/attachment/:attachmentID/content \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/chat-conversation/:chat-conversationID/attachment/:attachmentID/content
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/chat-conversation/:chat-conversationID/attachment/:attachmentID/content")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_Content_for_User_ExportAnnualOverview
{{baseUrl}}/user/:userID/export-annual-overview/:export-annual-overviewID/content
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
export-annual-overviewID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/export-annual-overview/:export-annual-overviewID/content");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/export-annual-overview/:export-annual-overviewID/content" {:headers {:user-agent ""
                                                                                                                           :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/export-annual-overview/:export-annual-overviewID/content"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/export-annual-overview/:export-annual-overviewID/content"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/export-annual-overview/:export-annual-overviewID/content");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/export-annual-overview/:export-annual-overviewID/content"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/export-annual-overview/:export-annual-overviewID/content HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/export-annual-overview/:export-annual-overviewID/content")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/export-annual-overview/:export-annual-overviewID/content"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/export-annual-overview/:export-annual-overviewID/content")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/export-annual-overview/:export-annual-overviewID/content")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/export-annual-overview/:export-annual-overviewID/content');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/export-annual-overview/:export-annual-overviewID/content',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/export-annual-overview/:export-annual-overviewID/content';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/export-annual-overview/:export-annual-overviewID/content',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/export-annual-overview/:export-annual-overviewID/content")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/export-annual-overview/:export-annual-overviewID/content',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/export-annual-overview/:export-annual-overviewID/content',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/export-annual-overview/:export-annual-overviewID/content');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/export-annual-overview/:export-annual-overviewID/content',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/export-annual-overview/:export-annual-overviewID/content';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/export-annual-overview/:export-annual-overviewID/content"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/export-annual-overview/:export-annual-overviewID/content" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/export-annual-overview/:export-annual-overviewID/content",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/export-annual-overview/:export-annual-overviewID/content', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/export-annual-overview/:export-annual-overviewID/content');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/export-annual-overview/:export-annual-overviewID/content');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/export-annual-overview/:export-annual-overviewID/content' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/export-annual-overview/:export-annual-overviewID/content' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/export-annual-overview/:export-annual-overviewID/content", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/export-annual-overview/:export-annual-overviewID/content"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/export-annual-overview/:export-annual-overviewID/content"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/export-annual-overview/:export-annual-overviewID/content")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/export-annual-overview/:export-annual-overviewID/content') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/export-annual-overview/:export-annual-overviewID/content";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/export-annual-overview/:export-annual-overviewID/content \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/export-annual-overview/:export-annual-overviewID/content \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/export-annual-overview/:export-annual-overviewID/content
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/export-annual-overview/:export-annual-overviewID/content")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_Content_for_User_MonetaryAccount_Attachment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment/:attachmentID/content
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
attachmentID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment/:attachmentID/content");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment/:attachmentID/content" {:headers {:user-agent ""
                                                                                                                                        :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment/:attachmentID/content"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment/:attachmentID/content"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment/:attachmentID/content");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment/:attachmentID/content"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/attachment/:attachmentID/content HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment/:attachmentID/content")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment/:attachmentID/content"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment/:attachmentID/content")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment/:attachmentID/content")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment/:attachmentID/content');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment/:attachmentID/content',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment/:attachmentID/content';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment/:attachmentID/content',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment/:attachmentID/content")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/attachment/:attachmentID/content',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment/:attachmentID/content',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment/:attachmentID/content');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment/:attachmentID/content',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment/:attachmentID/content';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment/:attachmentID/content"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment/:attachmentID/content" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment/:attachmentID/content",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment/:attachmentID/content', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment/:attachmentID/content');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment/:attachmentID/content');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment/:attachmentID/content' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment/:attachmentID/content' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/attachment/:attachmentID/content", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment/:attachmentID/content"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment/:attachmentID/content"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment/:attachmentID/content")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/attachment/:attachmentID/content') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment/:attachmentID/content";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment/:attachmentID/content \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment/:attachmentID/content \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment/:attachmentID/content
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/attachment/:attachmentID/content")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_Content_for_User_MonetaryAccount_CustomerStatement
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:customer-statementID/content
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
customer-statementID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:customer-statementID/content");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:customer-statementID/content" {:headers {:user-agent ""
                                                                                                                                                        :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:customer-statementID/content"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:customer-statementID/content"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:customer-statementID/content");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:customer-statementID/content"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/customer-statement/:customer-statementID/content HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:customer-statementID/content")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:customer-statementID/content"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:customer-statementID/content")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:customer-statementID/content")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:customer-statementID/content');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:customer-statementID/content',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:customer-statementID/content';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:customer-statementID/content',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:customer-statementID/content")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/customer-statement/:customer-statementID/content',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:customer-statementID/content',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:customer-statementID/content');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:customer-statementID/content',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:customer-statementID/content';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:customer-statementID/content"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:customer-statementID/content" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:customer-statementID/content",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:customer-statementID/content', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:customer-statementID/content');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:customer-statementID/content');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:customer-statementID/content' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:customer-statementID/content' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/customer-statement/:customer-statementID/content", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:customer-statementID/content"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:customer-statementID/content"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:customer-statementID/content")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/customer-statement/:customer-statementID/content') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:customer-statementID/content";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:customer-statementID/content \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:customer-statementID/content \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:customer-statementID/content
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:customer-statementID/content")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_Content_for_User_MonetaryAccount_Event_Statement
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:statementID/content
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
eventID
statementID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:statementID/content");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:statementID/content" {:headers {:user-agent ""
                                                                                                                                                     :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:statementID/content"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:statementID/content"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:statementID/content");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:statementID/content"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:statementID/content HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:statementID/content")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:statementID/content"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:statementID/content")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:statementID/content")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:statementID/content');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:statementID/content',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:statementID/content';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:statementID/content',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:statementID/content")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:statementID/content',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:statementID/content',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:statementID/content');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:statementID/content',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:statementID/content';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:statementID/content"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:statementID/content" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:statementID/content",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:statementID/content', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:statementID/content');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:statementID/content');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:statementID/content' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:statementID/content' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:statementID/content", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:statementID/content"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:statementID/content"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:statementID/content")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:statementID/content') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:statementID/content";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:statementID/content \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:statementID/content \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:statementID/content
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:statementID/content")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_Content_for_User_MonetaryAccount_ExportRib
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:export-ribID/content
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
export-ribID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:export-ribID/content");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:export-ribID/content" {:headers {:user-agent ""
                                                                                                                                        :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:export-ribID/content"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:export-ribID/content"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:export-ribID/content");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:export-ribID/content"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/export-rib/:export-ribID/content HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:export-ribID/content")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:export-ribID/content"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:export-ribID/content")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:export-ribID/content")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:export-ribID/content');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:export-ribID/content',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:export-ribID/content';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:export-ribID/content',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:export-ribID/content")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/export-rib/:export-ribID/content',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:export-ribID/content',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:export-ribID/content');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:export-ribID/content',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:export-ribID/content';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:export-ribID/content"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:export-ribID/content" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:export-ribID/content",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:export-ribID/content', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:export-ribID/content');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:export-ribID/content');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:export-ribID/content' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:export-ribID/content' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/export-rib/:export-ribID/content", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:export-ribID/content"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:export-ribID/content"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:export-ribID/content")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/export-rib/:export-ribID/content') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:export-ribID/content";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:export-ribID/content \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:export-ribID/content \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:export-ribID/content
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:export-ribID/content")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_CredentialPasswordIp_for_User
{{baseUrl}}/user/:userID/credential-password-ip
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/credential-password-ip");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/credential-password-ip" {:headers {:user-agent ""
                                                                                         :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/credential-password-ip"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/credential-password-ip"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/credential-password-ip");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/credential-password-ip"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/credential-password-ip HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/credential-password-ip")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/credential-password-ip"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/credential-password-ip")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/credential-password-ip")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/credential-password-ip');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/credential-password-ip',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/credential-password-ip';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/credential-password-ip',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/credential-password-ip")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/credential-password-ip',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/credential-password-ip',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/credential-password-ip');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/credential-password-ip',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/credential-password-ip';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/credential-password-ip"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/credential-password-ip" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/credential-password-ip",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/credential-password-ip', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/credential-password-ip');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/credential-password-ip');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/credential-password-ip' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/credential-password-ip' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/credential-password-ip", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/credential-password-ip"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/credential-password-ip"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/credential-password-ip")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/credential-password-ip') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/credential-password-ip";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/credential-password-ip \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/credential-password-ip \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/credential-password-ip
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/credential-password-ip")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_CredentialPasswordIp_for_User
{{baseUrl}}/user/:userID/credential-password-ip/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/credential-password-ip/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/credential-password-ip/:itemId" {:headers {:user-agent ""
                                                                                                 :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/credential-password-ip/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/credential-password-ip/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/credential-password-ip/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/credential-password-ip/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/credential-password-ip/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/credential-password-ip/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/credential-password-ip/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/credential-password-ip/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/credential-password-ip/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/credential-password-ip/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/credential-password-ip/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/credential-password-ip/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/credential-password-ip/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/credential-password-ip/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/credential-password-ip/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/credential-password-ip/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/credential-password-ip/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/credential-password-ip/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/credential-password-ip/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/credential-password-ip/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/credential-password-ip/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/credential-password-ip/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/credential-password-ip/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/credential-password-ip/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/credential-password-ip/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/credential-password-ip/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/credential-password-ip/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/credential-password-ip/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/credential-password-ip/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/credential-password-ip/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/credential-password-ip/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/credential-password-ip/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/credential-password-ip/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/credential-password-ip/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/credential-password-ip/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/credential-password-ip/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/credential-password-ip/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_CurrencyCloudBeneficiary_for_User
{{baseUrl}}/user/:userID/currency-cloud-beneficiary
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
BODY json

{
  "all_field": [],
  "country": "",
  "currency": "",
  "legal_entity_type": "",
  "name": "",
  "payment_type": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/currency-cloud-beneficiary");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"all_field\": [],\n  \"country\": \"\",\n  \"currency\": \"\",\n  \"legal_entity_type\": \"\",\n  \"name\": \"\",\n  \"payment_type\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/currency-cloud-beneficiary" {:headers {:user-agent ""
                                                                                              :x-bunq-client-authentication ""}
                                                                                    :content-type :json
                                                                                    :form-params {:all_field []
                                                                                                  :country ""
                                                                                                  :currency ""
                                                                                                  :legal_entity_type ""
                                                                                                  :name ""
                                                                                                  :payment_type ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/currency-cloud-beneficiary"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"all_field\": [],\n  \"country\": \"\",\n  \"currency\": \"\",\n  \"legal_entity_type\": \"\",\n  \"name\": \"\",\n  \"payment_type\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/currency-cloud-beneficiary"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"all_field\": [],\n  \"country\": \"\",\n  \"currency\": \"\",\n  \"legal_entity_type\": \"\",\n  \"name\": \"\",\n  \"payment_type\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/currency-cloud-beneficiary");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"all_field\": [],\n  \"country\": \"\",\n  \"currency\": \"\",\n  \"legal_entity_type\": \"\",\n  \"name\": \"\",\n  \"payment_type\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/currency-cloud-beneficiary"

	payload := strings.NewReader("{\n  \"all_field\": [],\n  \"country\": \"\",\n  \"currency\": \"\",\n  \"legal_entity_type\": \"\",\n  \"name\": \"\",\n  \"payment_type\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/currency-cloud-beneficiary HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 119

{
  "all_field": [],
  "country": "",
  "currency": "",
  "legal_entity_type": "",
  "name": "",
  "payment_type": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/currency-cloud-beneficiary")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"all_field\": [],\n  \"country\": \"\",\n  \"currency\": \"\",\n  \"legal_entity_type\": \"\",\n  \"name\": \"\",\n  \"payment_type\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/currency-cloud-beneficiary"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"all_field\": [],\n  \"country\": \"\",\n  \"currency\": \"\",\n  \"legal_entity_type\": \"\",\n  \"name\": \"\",\n  \"payment_type\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"all_field\": [],\n  \"country\": \"\",\n  \"currency\": \"\",\n  \"legal_entity_type\": \"\",\n  \"name\": \"\",\n  \"payment_type\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/currency-cloud-beneficiary")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/currency-cloud-beneficiary")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"all_field\": [],\n  \"country\": \"\",\n  \"currency\": \"\",\n  \"legal_entity_type\": \"\",\n  \"name\": \"\",\n  \"payment_type\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  all_field: [],
  country: '',
  currency: '',
  legal_entity_type: '',
  name: '',
  payment_type: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/currency-cloud-beneficiary');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/currency-cloud-beneficiary',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    all_field: [],
    country: '',
    currency: '',
    legal_entity_type: '',
    name: '',
    payment_type: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/currency-cloud-beneficiary';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"all_field":[],"country":"","currency":"","legal_entity_type":"","name":"","payment_type":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/currency-cloud-beneficiary',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "all_field": [],\n  "country": "",\n  "currency": "",\n  "legal_entity_type": "",\n  "name": "",\n  "payment_type": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"all_field\": [],\n  \"country\": \"\",\n  \"currency\": \"\",\n  \"legal_entity_type\": \"\",\n  \"name\": \"\",\n  \"payment_type\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/currency-cloud-beneficiary")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/currency-cloud-beneficiary',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  all_field: [],
  country: '',
  currency: '',
  legal_entity_type: '',
  name: '',
  payment_type: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/currency-cloud-beneficiary',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    all_field: [],
    country: '',
    currency: '',
    legal_entity_type: '',
    name: '',
    payment_type: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/currency-cloud-beneficiary');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  all_field: [],
  country: '',
  currency: '',
  legal_entity_type: '',
  name: '',
  payment_type: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/currency-cloud-beneficiary',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    all_field: [],
    country: '',
    currency: '',
    legal_entity_type: '',
    name: '',
    payment_type: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/currency-cloud-beneficiary';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"all_field":[],"country":"","currency":"","legal_entity_type":"","name":"","payment_type":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"all_field": @[  ],
                              @"country": @"",
                              @"currency": @"",
                              @"legal_entity_type": @"",
                              @"name": @"",
                              @"payment_type": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/currency-cloud-beneficiary"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/currency-cloud-beneficiary" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"all_field\": [],\n  \"country\": \"\",\n  \"currency\": \"\",\n  \"legal_entity_type\": \"\",\n  \"name\": \"\",\n  \"payment_type\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/currency-cloud-beneficiary",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'all_field' => [
        
    ],
    'country' => '',
    'currency' => '',
    'legal_entity_type' => '',
    'name' => '',
    'payment_type' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/currency-cloud-beneficiary', [
  'body' => '{
  "all_field": [],
  "country": "",
  "currency": "",
  "legal_entity_type": "",
  "name": "",
  "payment_type": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/currency-cloud-beneficiary');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'all_field' => [
    
  ],
  'country' => '',
  'currency' => '',
  'legal_entity_type' => '',
  'name' => '',
  'payment_type' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'all_field' => [
    
  ],
  'country' => '',
  'currency' => '',
  'legal_entity_type' => '',
  'name' => '',
  'payment_type' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/currency-cloud-beneficiary');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/currency-cloud-beneficiary' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "all_field": [],
  "country": "",
  "currency": "",
  "legal_entity_type": "",
  "name": "",
  "payment_type": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/currency-cloud-beneficiary' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "all_field": [],
  "country": "",
  "currency": "",
  "legal_entity_type": "",
  "name": "",
  "payment_type": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"all_field\": [],\n  \"country\": \"\",\n  \"currency\": \"\",\n  \"legal_entity_type\": \"\",\n  \"name\": \"\",\n  \"payment_type\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/currency-cloud-beneficiary", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/currency-cloud-beneficiary"

payload = {
    "all_field": [],
    "country": "",
    "currency": "",
    "legal_entity_type": "",
    "name": "",
    "payment_type": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/currency-cloud-beneficiary"

payload <- "{\n  \"all_field\": [],\n  \"country\": \"\",\n  \"currency\": \"\",\n  \"legal_entity_type\": \"\",\n  \"name\": \"\",\n  \"payment_type\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/currency-cloud-beneficiary")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"all_field\": [],\n  \"country\": \"\",\n  \"currency\": \"\",\n  \"legal_entity_type\": \"\",\n  \"name\": \"\",\n  \"payment_type\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/currency-cloud-beneficiary') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"all_field\": [],\n  \"country\": \"\",\n  \"currency\": \"\",\n  \"legal_entity_type\": \"\",\n  \"name\": \"\",\n  \"payment_type\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/currency-cloud-beneficiary";

    let payload = json!({
        "all_field": (),
        "country": "",
        "currency": "",
        "legal_entity_type": "",
        "name": "",
        "payment_type": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/currency-cloud-beneficiary \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "all_field": [],
  "country": "",
  "currency": "",
  "legal_entity_type": "",
  "name": "",
  "payment_type": ""
}'
echo '{
  "all_field": [],
  "country": "",
  "currency": "",
  "legal_entity_type": "",
  "name": "",
  "payment_type": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/currency-cloud-beneficiary \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "all_field": [],\n  "country": "",\n  "currency": "",\n  "legal_entity_type": "",\n  "name": "",\n  "payment_type": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/currency-cloud-beneficiary
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "all_field": [],
  "country": "",
  "currency": "",
  "legal_entity_type": "",
  "name": "",
  "payment_type": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/currency-cloud-beneficiary")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_CurrencyCloudBeneficiary_for_User
{{baseUrl}}/user/:userID/currency-cloud-beneficiary
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/currency-cloud-beneficiary");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/currency-cloud-beneficiary" {:headers {:user-agent ""
                                                                                             :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/currency-cloud-beneficiary"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/currency-cloud-beneficiary"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/currency-cloud-beneficiary");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/currency-cloud-beneficiary"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/currency-cloud-beneficiary HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/currency-cloud-beneficiary")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/currency-cloud-beneficiary"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/currency-cloud-beneficiary")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/currency-cloud-beneficiary")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/currency-cloud-beneficiary');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/currency-cloud-beneficiary',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/currency-cloud-beneficiary';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/currency-cloud-beneficiary',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/currency-cloud-beneficiary")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/currency-cloud-beneficiary',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/currency-cloud-beneficiary',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/currency-cloud-beneficiary');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/currency-cloud-beneficiary',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/currency-cloud-beneficiary';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/currency-cloud-beneficiary"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/currency-cloud-beneficiary" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/currency-cloud-beneficiary",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/currency-cloud-beneficiary', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/currency-cloud-beneficiary');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/currency-cloud-beneficiary');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/currency-cloud-beneficiary' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/currency-cloud-beneficiary' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/currency-cloud-beneficiary", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/currency-cloud-beneficiary"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/currency-cloud-beneficiary"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/currency-cloud-beneficiary")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/currency-cloud-beneficiary') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/currency-cloud-beneficiary";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/currency-cloud-beneficiary \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/currency-cloud-beneficiary \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/currency-cloud-beneficiary
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/currency-cloud-beneficiary")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_CurrencyCloudBeneficiary_for_User
{{baseUrl}}/user/:userID/currency-cloud-beneficiary/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/currency-cloud-beneficiary/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/currency-cloud-beneficiary/:itemId" {:headers {:user-agent ""
                                                                                                     :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/currency-cloud-beneficiary/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/currency-cloud-beneficiary/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/currency-cloud-beneficiary/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/currency-cloud-beneficiary/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/currency-cloud-beneficiary/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/currency-cloud-beneficiary/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/currency-cloud-beneficiary/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/currency-cloud-beneficiary/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/currency-cloud-beneficiary/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/currency-cloud-beneficiary/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/currency-cloud-beneficiary/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/currency-cloud-beneficiary/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/currency-cloud-beneficiary/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/currency-cloud-beneficiary/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/currency-cloud-beneficiary/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/currency-cloud-beneficiary/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/currency-cloud-beneficiary/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/currency-cloud-beneficiary/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/currency-cloud-beneficiary/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/currency-cloud-beneficiary/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/currency-cloud-beneficiary/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/currency-cloud-beneficiary/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/currency-cloud-beneficiary/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/currency-cloud-beneficiary/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/currency-cloud-beneficiary/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/currency-cloud-beneficiary/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/currency-cloud-beneficiary/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/currency-cloud-beneficiary/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/currency-cloud-beneficiary/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/currency-cloud-beneficiary/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/currency-cloud-beneficiary/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/currency-cloud-beneficiary/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/currency-cloud-beneficiary/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/currency-cloud-beneficiary/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/currency-cloud-beneficiary/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/currency-cloud-beneficiary/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/currency-cloud-beneficiary/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_CurrencyCloudBeneficiaryRequirement_for_User
{{baseUrl}}/user/:userID/currency-cloud-beneficiary-requirement
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/currency-cloud-beneficiary-requirement");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/currency-cloud-beneficiary-requirement" {:headers {:user-agent ""
                                                                                                         :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/currency-cloud-beneficiary-requirement"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/currency-cloud-beneficiary-requirement"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/currency-cloud-beneficiary-requirement");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/currency-cloud-beneficiary-requirement"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/currency-cloud-beneficiary-requirement HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/currency-cloud-beneficiary-requirement")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/currency-cloud-beneficiary-requirement"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/currency-cloud-beneficiary-requirement")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/currency-cloud-beneficiary-requirement")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/currency-cloud-beneficiary-requirement');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/currency-cloud-beneficiary-requirement',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/currency-cloud-beneficiary-requirement';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/currency-cloud-beneficiary-requirement',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/currency-cloud-beneficiary-requirement")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/currency-cloud-beneficiary-requirement',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/currency-cloud-beneficiary-requirement',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/currency-cloud-beneficiary-requirement');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/currency-cloud-beneficiary-requirement',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/currency-cloud-beneficiary-requirement';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/currency-cloud-beneficiary-requirement"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/currency-cloud-beneficiary-requirement" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/currency-cloud-beneficiary-requirement",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/currency-cloud-beneficiary-requirement', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/currency-cloud-beneficiary-requirement');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/currency-cloud-beneficiary-requirement');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/currency-cloud-beneficiary-requirement' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/currency-cloud-beneficiary-requirement' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/currency-cloud-beneficiary-requirement", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/currency-cloud-beneficiary-requirement"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/currency-cloud-beneficiary-requirement"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/currency-cloud-beneficiary-requirement")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/currency-cloud-beneficiary-requirement') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/currency-cloud-beneficiary-requirement";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/currency-cloud-beneficiary-requirement \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/currency-cloud-beneficiary-requirement \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/currency-cloud-beneficiary-requirement
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/currency-cloud-beneficiary-requirement")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_CurrencyCloudPaymentQuote_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-cloud-payment-quote
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
BODY json

{
  "pointers": [
    {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    }
  ]
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-cloud-payment-quote");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"pointers\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ]\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-cloud-payment-quote" {:headers {:user-agent ""
                                                                                                                                     :x-bunq-client-authentication ""}
                                                                                                                           :content-type :json
                                                                                                                           :form-params {:pointers [{:name ""
                                                                                                                                                     :service ""
                                                                                                                                                     :type ""
                                                                                                                                                     :value ""}]}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-cloud-payment-quote"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"pointers\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ]\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-cloud-payment-quote"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"pointers\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ]\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-cloud-payment-quote");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"pointers\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ]\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-cloud-payment-quote"

	payload := strings.NewReader("{\n  \"pointers\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ]\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/currency-cloud-payment-quote HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 110

{
  "pointers": [
    {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    }
  ]
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-cloud-payment-quote")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"pointers\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ]\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-cloud-payment-quote"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"pointers\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ]\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"pointers\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ]\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-cloud-payment-quote")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-cloud-payment-quote")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"pointers\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ]\n}")
  .asString();
const data = JSON.stringify({
  pointers: [
    {
      name: '',
      service: '',
      type: '',
      value: ''
    }
  ]
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-cloud-payment-quote');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-cloud-payment-quote',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {pointers: [{name: '', service: '', type: '', value: ''}]}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-cloud-payment-quote';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"pointers":[{"name":"","service":"","type":"","value":""}]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-cloud-payment-quote',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "pointers": [\n    {\n      "name": "",\n      "service": "",\n      "type": "",\n      "value": ""\n    }\n  ]\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"pointers\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ]\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-cloud-payment-quote")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/currency-cloud-payment-quote',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({pointers: [{name: '', service: '', type: '', value: ''}]}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-cloud-payment-quote',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {pointers: [{name: '', service: '', type: '', value: ''}]},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-cloud-payment-quote');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  pointers: [
    {
      name: '',
      service: '',
      type: '',
      value: ''
    }
  ]
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-cloud-payment-quote',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {pointers: [{name: '', service: '', type: '', value: ''}]}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-cloud-payment-quote';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"pointers":[{"name":"","service":"","type":"","value":""}]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"pointers": @[ @{ @"name": @"", @"service": @"", @"type": @"", @"value": @"" } ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-cloud-payment-quote"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-cloud-payment-quote" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"pointers\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ]\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-cloud-payment-quote",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'pointers' => [
        [
                'name' => '',
                'service' => '',
                'type' => '',
                'value' => ''
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-cloud-payment-quote', [
  'body' => '{
  "pointers": [
    {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    }
  ]
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-cloud-payment-quote');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'pointers' => [
    [
        'name' => '',
        'service' => '',
        'type' => '',
        'value' => ''
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'pointers' => [
    [
        'name' => '',
        'service' => '',
        'type' => '',
        'value' => ''
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-cloud-payment-quote');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-cloud-payment-quote' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "pointers": [
    {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    }
  ]
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-cloud-payment-quote' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "pointers": [
    {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    }
  ]
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"pointers\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ]\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/currency-cloud-payment-quote", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-cloud-payment-quote"

payload = { "pointers": [
        {
            "name": "",
            "service": "",
            "type": "",
            "value": ""
        }
    ] }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-cloud-payment-quote"

payload <- "{\n  \"pointers\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ]\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-cloud-payment-quote")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"pointers\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ]\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/currency-cloud-payment-quote') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"pointers\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ]\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-cloud-payment-quote";

    let payload = json!({"pointers": (
            json!({
                "name": "",
                "service": "",
                "type": "",
                "value": ""
            })
        )});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-cloud-payment-quote \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "pointers": [
    {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    }
  ]
}'
echo '{
  "pointers": [
    {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    }
  ]
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-cloud-payment-quote \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "pointers": [\n    {\n      "name": "",\n      "service": "",\n      "type": "",\n      "value": ""\n    }\n  ]\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-cloud-payment-quote
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["pointers": [
    [
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    ]
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-cloud-payment-quote")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_CurrencyConversion_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion" {:headers {:user-agent ""
                                                                                                                           :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/currency-conversion HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/currency-conversion',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/currency-conversion", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/currency-conversion') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_CurrencyConversion_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion/:itemId" {:headers {:user-agent ""
                                                                                                                                   :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/currency-conversion/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/currency-conversion/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/currency-conversion/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/currency-conversion/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_CurrencyConversionQuote_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
BODY json

{
  "amount": {
    "currency": "",
    "value": ""
  },
  "counterparty_alias": {
    "name": "",
    "service": "",
    "type": "",
    "value": ""
  },
  "currency_source": "",
  "currency_target": "",
  "status": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"status\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote" {:headers {:user-agent ""
                                                                                                                                  :x-bunq-client-authentication ""}
                                                                                                                        :content-type :json
                                                                                                                        :form-params {:amount {:currency ""
                                                                                                                                               :value ""}
                                                                                                                                      :counterparty_alias {:name ""
                                                                                                                                                           :service ""
                                                                                                                                                           :type ""
                                                                                                                                                           :value ""}
                                                                                                                                      :currency_source ""
                                                                                                                                      :currency_target ""
                                                                                                                                      :status ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"status\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"status\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"status\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote"

	payload := strings.NewReader("{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"status\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 221

{
  "amount": {
    "currency": "",
    "value": ""
  },
  "counterparty_alias": {
    "name": "",
    "service": "",
    "type": "",
    "value": ""
  },
  "currency_source": "",
  "currency_target": "",
  "status": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"status\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"status\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"status\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"status\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  amount: {
    currency: '',
    value: ''
  },
  counterparty_alias: {
    name: '',
    service: '',
    type: '',
    value: ''
  },
  currency_source: '',
  currency_target: '',
  status: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    amount: {currency: '', value: ''},
    counterparty_alias: {name: '', service: '', type: '', value: ''},
    currency_source: '',
    currency_target: '',
    status: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"amount":{"currency":"","value":""},"counterparty_alias":{"name":"","service":"","type":"","value":""},"currency_source":"","currency_target":"","status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "amount": {\n    "currency": "",\n    "value": ""\n  },\n  "counterparty_alias": {\n    "name": "",\n    "service": "",\n    "type": "",\n    "value": ""\n  },\n  "currency_source": "",\n  "currency_target": "",\n  "status": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"status\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  amount: {currency: '', value: ''},
  counterparty_alias: {name: '', service: '', type: '', value: ''},
  currency_source: '',
  currency_target: '',
  status: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    amount: {currency: '', value: ''},
    counterparty_alias: {name: '', service: '', type: '', value: ''},
    currency_source: '',
    currency_target: '',
    status: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  amount: {
    currency: '',
    value: ''
  },
  counterparty_alias: {
    name: '',
    service: '',
    type: '',
    value: ''
  },
  currency_source: '',
  currency_target: '',
  status: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    amount: {currency: '', value: ''},
    counterparty_alias: {name: '', service: '', type: '', value: ''},
    currency_source: '',
    currency_target: '',
    status: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"amount":{"currency":"","value":""},"counterparty_alias":{"name":"","service":"","type":"","value":""},"currency_source":"","currency_target":"","status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"amount": @{ @"currency": @"", @"value": @"" },
                              @"counterparty_alias": @{ @"name": @"", @"service": @"", @"type": @"", @"value": @"" },
                              @"currency_source": @"",
                              @"currency_target": @"",
                              @"status": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"status\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'amount' => [
        'currency' => '',
        'value' => ''
    ],
    'counterparty_alias' => [
        'name' => '',
        'service' => '',
        'type' => '',
        'value' => ''
    ],
    'currency_source' => '',
    'currency_target' => '',
    'status' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote', [
  'body' => '{
  "amount": {
    "currency": "",
    "value": ""
  },
  "counterparty_alias": {
    "name": "",
    "service": "",
    "type": "",
    "value": ""
  },
  "currency_source": "",
  "currency_target": "",
  "status": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'amount' => [
    'currency' => '',
    'value' => ''
  ],
  'counterparty_alias' => [
    'name' => '',
    'service' => '',
    'type' => '',
    'value' => ''
  ],
  'currency_source' => '',
  'currency_target' => '',
  'status' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'amount' => [
    'currency' => '',
    'value' => ''
  ],
  'counterparty_alias' => [
    'name' => '',
    'service' => '',
    'type' => '',
    'value' => ''
  ],
  'currency_source' => '',
  'currency_target' => '',
  'status' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "amount": {
    "currency": "",
    "value": ""
  },
  "counterparty_alias": {
    "name": "",
    "service": "",
    "type": "",
    "value": ""
  },
  "currency_source": "",
  "currency_target": "",
  "status": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "amount": {
    "currency": "",
    "value": ""
  },
  "counterparty_alias": {
    "name": "",
    "service": "",
    "type": "",
    "value": ""
  },
  "currency_source": "",
  "currency_target": "",
  "status": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"status\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote"

payload = {
    "amount": {
        "currency": "",
        "value": ""
    },
    "counterparty_alias": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
    },
    "currency_source": "",
    "currency_target": "",
    "status": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote"

payload <- "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"status\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"status\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"status\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote";

    let payload = json!({
        "amount": json!({
            "currency": "",
            "value": ""
        }),
        "counterparty_alias": json!({
            "name": "",
            "service": "",
            "type": "",
            "value": ""
        }),
        "currency_source": "",
        "currency_target": "",
        "status": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "amount": {
    "currency": "",
    "value": ""
  },
  "counterparty_alias": {
    "name": "",
    "service": "",
    "type": "",
    "value": ""
  },
  "currency_source": "",
  "currency_target": "",
  "status": ""
}'
echo '{
  "amount": {
    "currency": "",
    "value": ""
  },
  "counterparty_alias": {
    "name": "",
    "service": "",
    "type": "",
    "value": ""
  },
  "currency_source": "",
  "currency_target": "",
  "status": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "amount": {\n    "currency": "",\n    "value": ""\n  },\n  "counterparty_alias": {\n    "name": "",\n    "service": "",\n    "type": "",\n    "value": ""\n  },\n  "currency_source": "",\n  "currency_target": "",\n  "status": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "amount": [
    "currency": "",
    "value": ""
  ],
  "counterparty_alias": [
    "name": "",
    "service": "",
    "type": "",
    "value": ""
  ],
  "currency_source": "",
  "currency_target": "",
  "status": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_CurrencyConversionQuote_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId" {:headers {:user-agent ""
                                                                                                                                         :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_CurrencyConversionQuote_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
itemId
BODY json

{
  "amount": {
    "currency": "",
    "value": ""
  },
  "counterparty_alias": {
    "name": "",
    "service": "",
    "type": "",
    "value": ""
  },
  "currency_source": "",
  "currency_target": "",
  "status": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"status\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId" {:headers {:user-agent ""
                                                                                                                                         :x-bunq-client-authentication ""}
                                                                                                                               :content-type :json
                                                                                                                               :form-params {:amount {:currency ""
                                                                                                                                                      :value ""}
                                                                                                                                             :counterparty_alias {:name ""
                                                                                                                                                                  :service ""
                                                                                                                                                                  :type ""
                                                                                                                                                                  :value ""}
                                                                                                                                             :currency_source ""
                                                                                                                                             :currency_target ""
                                                                                                                                             :status ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"status\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"status\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"status\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId"

	payload := strings.NewReader("{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"status\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 221

{
  "amount": {
    "currency": "",
    "value": ""
  },
  "counterparty_alias": {
    "name": "",
    "service": "",
    "type": "",
    "value": ""
  },
  "currency_source": "",
  "currency_target": "",
  "status": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"status\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"status\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"status\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"status\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  amount: {
    currency: '',
    value: ''
  },
  counterparty_alias: {
    name: '',
    service: '',
    type: '',
    value: ''
  },
  currency_source: '',
  currency_target: '',
  status: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    amount: {currency: '', value: ''},
    counterparty_alias: {name: '', service: '', type: '', value: ''},
    currency_source: '',
    currency_target: '',
    status: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"amount":{"currency":"","value":""},"counterparty_alias":{"name":"","service":"","type":"","value":""},"currency_source":"","currency_target":"","status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "amount": {\n    "currency": "",\n    "value": ""\n  },\n  "counterparty_alias": {\n    "name": "",\n    "service": "",\n    "type": "",\n    "value": ""\n  },\n  "currency_source": "",\n  "currency_target": "",\n  "status": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"status\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  amount: {currency: '', value: ''},
  counterparty_alias: {name: '', service: '', type: '', value: ''},
  currency_source: '',
  currency_target: '',
  status: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    amount: {currency: '', value: ''},
    counterparty_alias: {name: '', service: '', type: '', value: ''},
    currency_source: '',
    currency_target: '',
    status: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  amount: {
    currency: '',
    value: ''
  },
  counterparty_alias: {
    name: '',
    service: '',
    type: '',
    value: ''
  },
  currency_source: '',
  currency_target: '',
  status: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    amount: {currency: '', value: ''},
    counterparty_alias: {name: '', service: '', type: '', value: ''},
    currency_source: '',
    currency_target: '',
    status: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"amount":{"currency":"","value":""},"counterparty_alias":{"name":"","service":"","type":"","value":""},"currency_source":"","currency_target":"","status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"amount": @{ @"currency": @"", @"value": @"" },
                              @"counterparty_alias": @{ @"name": @"", @"service": @"", @"type": @"", @"value": @"" },
                              @"currency_source": @"",
                              @"currency_target": @"",
                              @"status": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"status\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'amount' => [
        'currency' => '',
        'value' => ''
    ],
    'counterparty_alias' => [
        'name' => '',
        'service' => '',
        'type' => '',
        'value' => ''
    ],
    'currency_source' => '',
    'currency_target' => '',
    'status' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId', [
  'body' => '{
  "amount": {
    "currency": "",
    "value": ""
  },
  "counterparty_alias": {
    "name": "",
    "service": "",
    "type": "",
    "value": ""
  },
  "currency_source": "",
  "currency_target": "",
  "status": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'amount' => [
    'currency' => '',
    'value' => ''
  ],
  'counterparty_alias' => [
    'name' => '',
    'service' => '',
    'type' => '',
    'value' => ''
  ],
  'currency_source' => '',
  'currency_target' => '',
  'status' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'amount' => [
    'currency' => '',
    'value' => ''
  ],
  'counterparty_alias' => [
    'name' => '',
    'service' => '',
    'type' => '',
    'value' => ''
  ],
  'currency_source' => '',
  'currency_target' => '',
  'status' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "amount": {
    "currency": "",
    "value": ""
  },
  "counterparty_alias": {
    "name": "",
    "service": "",
    "type": "",
    "value": ""
  },
  "currency_source": "",
  "currency_target": "",
  "status": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "amount": {
    "currency": "",
    "value": ""
  },
  "counterparty_alias": {
    "name": "",
    "service": "",
    "type": "",
    "value": ""
  },
  "currency_source": "",
  "currency_target": "",
  "status": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"status\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId"

payload = {
    "amount": {
        "currency": "",
        "value": ""
    },
    "counterparty_alias": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
    },
    "currency_source": "",
    "currency_target": "",
    "status": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId"

payload <- "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"status\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"status\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_alias\": {\n    \"name\": \"\",\n    \"service\": \"\",\n    \"type\": \"\",\n    \"value\": \"\"\n  },\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"status\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId";

    let payload = json!({
        "amount": json!({
            "currency": "",
            "value": ""
        }),
        "counterparty_alias": json!({
            "name": "",
            "service": "",
            "type": "",
            "value": ""
        }),
        "currency_source": "",
        "currency_target": "",
        "status": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "amount": {
    "currency": "",
    "value": ""
  },
  "counterparty_alias": {
    "name": "",
    "service": "",
    "type": "",
    "value": ""
  },
  "currency_source": "",
  "currency_target": "",
  "status": ""
}'
echo '{
  "amount": {
    "currency": "",
    "value": ""
  },
  "counterparty_alias": {
    "name": "",
    "service": "",
    "type": "",
    "value": ""
  },
  "currency_source": "",
  "currency_target": "",
  "status": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "amount": {\n    "currency": "",\n    "value": ""\n  },\n  "counterparty_alias": {\n    "name": "",\n    "service": "",\n    "type": "",\n    "value": ""\n  },\n  "currency_source": "",\n  "currency_target": "",\n  "status": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "amount": [
    "currency": "",
    "value": ""
  ],
  "counterparty_alias": [
    "name": "",
    "service": "",
    "type": "",
    "value": ""
  ],
  "currency_source": "",
  "currency_target": "",
  "status": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/currency-conversion-quote/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_CustomerStatement_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
BODY json

{
  "date_end": "",
  "date_start": "",
  "include_attachment": false,
  "regional_format": "",
  "statement_format": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"date_end\": \"\",\n  \"date_start\": \"\",\n  \"include_attachment\": false,\n  \"regional_format\": \"\",\n  \"statement_format\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement" {:headers {:user-agent ""
                                                                                                                           :x-bunq-client-authentication ""}
                                                                                                                 :content-type :json
                                                                                                                 :form-params {:date_end ""
                                                                                                                               :date_start ""
                                                                                                                               :include_attachment false
                                                                                                                               :regional_format ""
                                                                                                                               :statement_format ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"date_end\": \"\",\n  \"date_start\": \"\",\n  \"include_attachment\": false,\n  \"regional_format\": \"\",\n  \"statement_format\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"date_end\": \"\",\n  \"date_start\": \"\",\n  \"include_attachment\": false,\n  \"regional_format\": \"\",\n  \"statement_format\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"date_end\": \"\",\n  \"date_start\": \"\",\n  \"include_attachment\": false,\n  \"regional_format\": \"\",\n  \"statement_format\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement"

	payload := strings.NewReader("{\n  \"date_end\": \"\",\n  \"date_start\": \"\",\n  \"include_attachment\": false,\n  \"regional_format\": \"\",\n  \"statement_format\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/customer-statement HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 122

{
  "date_end": "",
  "date_start": "",
  "include_attachment": false,
  "regional_format": "",
  "statement_format": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"date_end\": \"\",\n  \"date_start\": \"\",\n  \"include_attachment\": false,\n  \"regional_format\": \"\",\n  \"statement_format\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"date_end\": \"\",\n  \"date_start\": \"\",\n  \"include_attachment\": false,\n  \"regional_format\": \"\",\n  \"statement_format\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"date_end\": \"\",\n  \"date_start\": \"\",\n  \"include_attachment\": false,\n  \"regional_format\": \"\",\n  \"statement_format\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"date_end\": \"\",\n  \"date_start\": \"\",\n  \"include_attachment\": false,\n  \"regional_format\": \"\",\n  \"statement_format\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  date_end: '',
  date_start: '',
  include_attachment: false,
  regional_format: '',
  statement_format: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    date_end: '',
    date_start: '',
    include_attachment: false,
    regional_format: '',
    statement_format: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"date_end":"","date_start":"","include_attachment":false,"regional_format":"","statement_format":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "date_end": "",\n  "date_start": "",\n  "include_attachment": false,\n  "regional_format": "",\n  "statement_format": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"date_end\": \"\",\n  \"date_start\": \"\",\n  \"include_attachment\": false,\n  \"regional_format\": \"\",\n  \"statement_format\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/customer-statement',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  date_end: '',
  date_start: '',
  include_attachment: false,
  regional_format: '',
  statement_format: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    date_end: '',
    date_start: '',
    include_attachment: false,
    regional_format: '',
    statement_format: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  date_end: '',
  date_start: '',
  include_attachment: false,
  regional_format: '',
  statement_format: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/customer-statement',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    date_end: '',
    date_start: '',
    include_attachment: false,
    regional_format: '',
    statement_format: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"date_end":"","date_start":"","include_attachment":false,"regional_format":"","statement_format":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"date_end": @"",
                              @"date_start": @"",
                              @"include_attachment": @NO,
                              @"regional_format": @"",
                              @"statement_format": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"date_end\": \"\",\n  \"date_start\": \"\",\n  \"include_attachment\": false,\n  \"regional_format\": \"\",\n  \"statement_format\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'date_end' => '',
    'date_start' => '',
    'include_attachment' => null,
    'regional_format' => '',
    'statement_format' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement', [
  'body' => '{
  "date_end": "",
  "date_start": "",
  "include_attachment": false,
  "regional_format": "",
  "statement_format": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'date_end' => '',
  'date_start' => '',
  'include_attachment' => null,
  'regional_format' => '',
  'statement_format' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'date_end' => '',
  'date_start' => '',
  'include_attachment' => null,
  'regional_format' => '',
  'statement_format' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "date_end": "",
  "date_start": "",
  "include_attachment": false,
  "regional_format": "",
  "statement_format": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "date_end": "",
  "date_start": "",
  "include_attachment": false,
  "regional_format": "",
  "statement_format": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"date_end\": \"\",\n  \"date_start\": \"\",\n  \"include_attachment\": false,\n  \"regional_format\": \"\",\n  \"statement_format\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/customer-statement", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement"

payload = {
    "date_end": "",
    "date_start": "",
    "include_attachment": False,
    "regional_format": "",
    "statement_format": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement"

payload <- "{\n  \"date_end\": \"\",\n  \"date_start\": \"\",\n  \"include_attachment\": false,\n  \"regional_format\": \"\",\n  \"statement_format\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"date_end\": \"\",\n  \"date_start\": \"\",\n  \"include_attachment\": false,\n  \"regional_format\": \"\",\n  \"statement_format\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/customer-statement') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"date_end\": \"\",\n  \"date_start\": \"\",\n  \"include_attachment\": false,\n  \"regional_format\": \"\",\n  \"statement_format\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement";

    let payload = json!({
        "date_end": "",
        "date_start": "",
        "include_attachment": false,
        "regional_format": "",
        "statement_format": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "date_end": "",
  "date_start": "",
  "include_attachment": false,
  "regional_format": "",
  "statement_format": ""
}'
echo '{
  "date_end": "",
  "date_start": "",
  "include_attachment": false,
  "regional_format": "",
  "statement_format": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "date_end": "",\n  "date_start": "",\n  "include_attachment": false,\n  "regional_format": "",\n  "statement_format": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "date_end": "",
  "date_start": "",
  "include_attachment": false,
  "regional_format": "",
  "statement_format": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_CustomerStatement_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId" {:headers {:user-agent ""
                                                                                                                                     :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId"]
                                                       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}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_CustomerStatement_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement" {:headers {:user-agent ""
                                                                                                                          :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/customer-statement HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/customer-statement',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/customer-statement", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/customer-statement') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_CustomerStatement_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId" {:headers {:user-agent ""
                                                                                                                                  :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/customer-statement/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_Definition_for_User_MonetaryAccount_PaymentAutoAllocate
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/definition
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
payment-auto-allocateID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/definition");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/definition" {:headers {:user-agent ""
                                                                                                                                                                 :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/definition"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/definition"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/definition");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/definition"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/definition HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/definition")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/definition"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/definition")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/definition")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/definition');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/definition',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/definition';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/definition',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/definition")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/definition',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/definition',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/definition');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/definition',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/definition';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/definition"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/definition" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/definition",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/definition', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/definition');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/definition');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/definition' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/definition' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/definition", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/definition"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/definition"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/definition")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/definition') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/definition";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/definition \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/definition \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/definition
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/definition")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_Device
{{baseUrl}}/device
HEADERS

User-Agent
X-Bunq-Client-Authentication
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/device");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/device" {:headers {:user-agent ""
                                                            :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/device"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/device"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/device");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/device"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/device HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/device")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/device"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/device")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/device")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/device');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/device',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/device';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/device',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/device")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/device',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/device',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/device');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/device',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/device';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/device"]
                                                       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}}/device" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/device",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/device', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/device');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/device');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/device' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/device' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/device", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/device"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/device"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/device")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/device') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/device";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".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}}/device \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/device \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/device
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/device")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_Device
{{baseUrl}}/device/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/device/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/device/:itemId" {:headers {:user-agent ""
                                                                    :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/device/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/device/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/device/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/device/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/device/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/device/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/device/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/device/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/device/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/device/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/device/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/device/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/device/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/device/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/device/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/device/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/device/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/device/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/device/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/device/:itemId"]
                                                       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}}/device/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/device/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/device/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/device/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/device/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/device/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/device/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/device/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/device/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/device/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/device/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/device/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/device/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".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}}/device/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/device/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/device/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/device/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_DeviceServer
{{baseUrl}}/device-server
HEADERS

User-Agent
X-Bunq-Client-Authentication
BODY json

{
  "description": "",
  "permitted_ips": [],
  "secret": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/device-server");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"description\": \"\",\n  \"permitted_ips\": [],\n  \"secret\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/device-server" {:headers {:user-agent ""
                                                                    :x-bunq-client-authentication ""}
                                                          :content-type :json
                                                          :form-params {:description ""
                                                                        :permitted_ips []
                                                                        :secret ""}})
require "http/client"

url = "{{baseUrl}}/device-server"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"description\": \"\",\n  \"permitted_ips\": [],\n  \"secret\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/device-server"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"description\": \"\",\n  \"permitted_ips\": [],\n  \"secret\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/device-server");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"description\": \"\",\n  \"permitted_ips\": [],\n  \"secret\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/device-server"

	payload := strings.NewReader("{\n  \"description\": \"\",\n  \"permitted_ips\": [],\n  \"secret\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/device-server HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 62

{
  "description": "",
  "permitted_ips": [],
  "secret": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/device-server")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"description\": \"\",\n  \"permitted_ips\": [],\n  \"secret\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/device-server"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"description\": \"\",\n  \"permitted_ips\": [],\n  \"secret\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"description\": \"\",\n  \"permitted_ips\": [],\n  \"secret\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/device-server")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/device-server")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"description\": \"\",\n  \"permitted_ips\": [],\n  \"secret\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  description: '',
  permitted_ips: [],
  secret: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/device-server');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/device-server',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {description: '', permitted_ips: [], secret: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/device-server';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"description":"","permitted_ips":[],"secret":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/device-server',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "description": "",\n  "permitted_ips": [],\n  "secret": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"description\": \"\",\n  \"permitted_ips\": [],\n  \"secret\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/device-server")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/device-server',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({description: '', permitted_ips: [], secret: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/device-server',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {description: '', permitted_ips: [], secret: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/device-server');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  description: '',
  permitted_ips: [],
  secret: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/device-server',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {description: '', permitted_ips: [], secret: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/device-server';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"description":"","permitted_ips":[],"secret":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"description": @"",
                              @"permitted_ips": @[  ],
                              @"secret": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/device-server"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/device-server" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"description\": \"\",\n  \"permitted_ips\": [],\n  \"secret\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/device-server",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'description' => '',
    'permitted_ips' => [
        
    ],
    'secret' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/device-server', [
  'body' => '{
  "description": "",
  "permitted_ips": [],
  "secret": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/device-server');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'description' => '',
  'permitted_ips' => [
    
  ],
  'secret' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'description' => '',
  'permitted_ips' => [
    
  ],
  'secret' => ''
]));
$request->setRequestUrl('{{baseUrl}}/device-server');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/device-server' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "description": "",
  "permitted_ips": [],
  "secret": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/device-server' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "description": "",
  "permitted_ips": [],
  "secret": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"description\": \"\",\n  \"permitted_ips\": [],\n  \"secret\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/device-server", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/device-server"

payload = {
    "description": "",
    "permitted_ips": [],
    "secret": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/device-server"

payload <- "{\n  \"description\": \"\",\n  \"permitted_ips\": [],\n  \"secret\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/device-server")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"description\": \"\",\n  \"permitted_ips\": [],\n  \"secret\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/device-server') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"description\": \"\",\n  \"permitted_ips\": [],\n  \"secret\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/device-server";

    let payload = json!({
        "description": "",
        "permitted_ips": (),
        "secret": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/device-server \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "description": "",
  "permitted_ips": [],
  "secret": ""
}'
echo '{
  "description": "",
  "permitted_ips": [],
  "secret": ""
}' |  \
  http POST {{baseUrl}}/device-server \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "description": "",\n  "permitted_ips": [],\n  "secret": ""\n}' \
  --output-document \
  - {{baseUrl}}/device-server
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "description": "",
  "permitted_ips": [],
  "secret": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/device-server")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_DeviceServer
{{baseUrl}}/device-server
HEADERS

User-Agent
X-Bunq-Client-Authentication
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/device-server");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/device-server" {:headers {:user-agent ""
                                                                   :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/device-server"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/device-server"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/device-server");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/device-server"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/device-server HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/device-server")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/device-server"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/device-server")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/device-server")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/device-server');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/device-server',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/device-server';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/device-server',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/device-server")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/device-server',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/device-server',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/device-server');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/device-server',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/device-server';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/device-server"]
                                                       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}}/device-server" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/device-server",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/device-server', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/device-server');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/device-server');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/device-server' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/device-server' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/device-server", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/device-server"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/device-server"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/device-server")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/device-server') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/device-server";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".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}}/device-server \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/device-server \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/device-server
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/device-server")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_DeviceServer
{{baseUrl}}/device-server/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/device-server/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/device-server/:itemId" {:headers {:user-agent ""
                                                                           :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/device-server/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/device-server/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/device-server/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/device-server/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/device-server/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/device-server/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/device-server/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/device-server/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/device-server/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/device-server/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/device-server/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/device-server/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/device-server/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/device-server/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/device-server/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/device-server/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/device-server/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/device-server/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/device-server/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/device-server/:itemId"]
                                                       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}}/device-server/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/device-server/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/device-server/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/device-server/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/device-server/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/device-server/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/device-server/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/device-server/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/device-server/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/device-server/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/device-server/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/device-server/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/device-server/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".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}}/device-server/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/device-server/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/device-server/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/device-server/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_DraftPayment_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
BODY json

{
  "entries": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "counterparty_alias": {},
      "description": "",
      "id": 0,
      "merchant_reference": "",
      "type": ""
    }
  ],
  "number_of_required_accepts": 0,
  "previous_updated_timestamp": "",
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  },
  "status": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"entries\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"number_of_required_accepts\": 0,\n  \"previous_updated_timestamp\": \"\",\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment" {:headers {:user-agent ""
                                                                                                                      :x-bunq-client-authentication ""}
                                                                                                            :content-type :json
                                                                                                            :form-params {:entries [{:alias {:avatar {:anchor_uuid ""
                                                                                                                                                      :image [{:attachment_public_uuid ""
                                                                                                                                                               :content_type ""
                                                                                                                                                               :height 0
                                                                                                                                                               :width 0}]
                                                                                                                                                      :style ""
                                                                                                                                                      :uuid ""}
                                                                                                                                             :bunq_me {:name ""
                                                                                                                                                       :service ""
                                                                                                                                                       :type ""
                                                                                                                                                       :value ""}
                                                                                                                                             :country ""
                                                                                                                                             :display_name ""
                                                                                                                                             :iban ""
                                                                                                                                             :is_light false
                                                                                                                                             :label_user {:avatar {}
                                                                                                                                                          :country ""
                                                                                                                                                          :display_name ""
                                                                                                                                                          :public_nick_name ""
                                                                                                                                                          :uuid ""}
                                                                                                                                             :merchant_category_code ""
                                                                                                                                             :swift_account_number ""
                                                                                                                                             :swift_bic ""
                                                                                                                                             :transferwise_account_number ""
                                                                                                                                             :transferwise_bank_code ""}
                                                                                                                                     :amount {:currency ""
                                                                                                                                              :value ""}
                                                                                                                                     :attachment [{:id 0
                                                                                                                                                   :monetary_account_id 0}]
                                                                                                                                     :counterparty_alias {}
                                                                                                                                     :description ""
                                                                                                                                     :id 0
                                                                                                                                     :merchant_reference ""
                                                                                                                                     :type ""}]
                                                                                                                          :number_of_required_accepts 0
                                                                                                                          :previous_updated_timestamp ""
                                                                                                                          :schedule {:object {:Payment {:address_billing {:city ""
                                                                                                                                                                          :country ""
                                                                                                                                                                          :extra ""
                                                                                                                                                                          :house_number ""
                                                                                                                                                                          :is_user_address_updated false
                                                                                                                                                                          :mailbox_name ""
                                                                                                                                                                          :po_box ""
                                                                                                                                                                          :postal_code ""
                                                                                                                                                                          :province ""
                                                                                                                                                                          :street ""}
                                                                                                                                                        :address_shipping {}
                                                                                                                                                        :alias {}
                                                                                                                                                        :allow_bunqto false
                                                                                                                                                        :amount {}
                                                                                                                                                        :attachment [{}]
                                                                                                                                                        :balance_after_mutation {}
                                                                                                                                                        :batch_id 0
                                                                                                                                                        :bunqto_expiry ""
                                                                                                                                                        :bunqto_share_url ""
                                                                                                                                                        :bunqto_status ""
                                                                                                                                                        :bunqto_sub_status ""
                                                                                                                                                        :bunqto_time_responded ""
                                                                                                                                                        :counterparty_alias {}
                                                                                                                                                        :created ""
                                                                                                                                                        :description ""
                                                                                                                                                        :geolocation {:altitude 0
                                                                                                                                                                      :latitude 0
                                                                                                                                                                      :longitude 0
                                                                                                                                                                      :radius 0}
                                                                                                                                                        :id 0
                                                                                                                                                        :merchant_reference ""
                                                                                                                                                        :monetary_account_id 0
                                                                                                                                                        :payment_auto_allocate_instance {:created ""
                                                                                                                                                                                         :error_message []
                                                                                                                                                                                         :id 0
                                                                                                                                                                                         :payment_auto_allocate_id 0
                                                                                                                                                                                         :payment_batch {:payments {:Payment []}}
                                                                                                                                                                                         :payment_id 0
                                                                                                                                                                                         :status ""
                                                                                                                                                                                         :updated ""}
                                                                                                                                                        :request_reference_split_the_bill [{:id 0
                                                                                                                                                                                            :type ""}]
                                                                                                                                                        :scheduled_id 0
                                                                                                                                                        :sub_type ""
                                                                                                                                                        :type ""
                                                                                                                                                        :updated ""}
                                                                                                                                              :PaymentBatch {}}
                                                                                                                                     :recurrence_size 0
                                                                                                                                     :recurrence_unit ""
                                                                                                                                     :status ""
                                                                                                                                     :time_end ""
                                                                                                                                     :time_start ""}
                                                                                                                          :status ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"entries\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"number_of_required_accepts\": 0,\n  \"previous_updated_timestamp\": \"\",\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"entries\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"number_of_required_accepts\": 0,\n  \"previous_updated_timestamp\": \"\",\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"entries\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"number_of_required_accepts\": 0,\n  \"previous_updated_timestamp\": \"\",\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment"

	payload := strings.NewReader("{\n  \"entries\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"number_of_required_accepts\": 0,\n  \"previous_updated_timestamp\": \"\",\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 3086

{
  "entries": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "counterparty_alias": {},
      "description": "",
      "id": 0,
      "merchant_reference": "",
      "type": ""
    }
  ],
  "number_of_required_accepts": 0,
  "previous_updated_timestamp": "",
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  },
  "status": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"entries\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"number_of_required_accepts\": 0,\n  \"previous_updated_timestamp\": \"\",\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"entries\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"number_of_required_accepts\": 0,\n  \"previous_updated_timestamp\": \"\",\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"entries\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"number_of_required_accepts\": 0,\n  \"previous_updated_timestamp\": \"\",\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"entries\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"number_of_required_accepts\": 0,\n  \"previous_updated_timestamp\": \"\",\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  entries: [
    {
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [
            {
              attachment_public_uuid: '',
              content_type: '',
              height: 0,
              width: 0
            }
          ],
          style: '',
          uuid: ''
        },
        bunq_me: {
          name: '',
          service: '',
          type: '',
          value: ''
        },
        country: '',
        display_name: '',
        iban: '',
        is_light: false,
        label_user: {
          avatar: {},
          country: '',
          display_name: '',
          public_nick_name: '',
          uuid: ''
        },
        merchant_category_code: '',
        swift_account_number: '',
        swift_bic: '',
        transferwise_account_number: '',
        transferwise_bank_code: ''
      },
      amount: {
        currency: '',
        value: ''
      },
      attachment: [
        {
          id: 0,
          monetary_account_id: 0
        }
      ],
      counterparty_alias: {},
      description: '',
      id: 0,
      merchant_reference: '',
      type: ''
    }
  ],
  number_of_required_accepts: 0,
  previous_updated_timestamp: '',
  schedule: {
    object: {
      Payment: {
        address_billing: {
          city: '',
          country: '',
          extra: '',
          house_number: '',
          is_user_address_updated: false,
          mailbox_name: '',
          po_box: '',
          postal_code: '',
          province: '',
          street: ''
        },
        address_shipping: {},
        alias: {},
        allow_bunqto: false,
        amount: {},
        attachment: [
          {}
        ],
        balance_after_mutation: {},
        batch_id: 0,
        bunqto_expiry: '',
        bunqto_share_url: '',
        bunqto_status: '',
        bunqto_sub_status: '',
        bunqto_time_responded: '',
        counterparty_alias: {},
        created: '',
        description: '',
        geolocation: {
          altitude: 0,
          latitude: 0,
          longitude: 0,
          radius: 0
        },
        id: 0,
        merchant_reference: '',
        monetary_account_id: 0,
        payment_auto_allocate_instance: {
          created: '',
          error_message: [],
          id: 0,
          payment_auto_allocate_id: 0,
          payment_batch: {
            payments: {
              Payment: []
            }
          },
          payment_id: 0,
          status: '',
          updated: ''
        },
        request_reference_split_the_bill: [
          {
            id: 0,
            type: ''
          }
        ],
        scheduled_id: 0,
        sub_type: '',
        type: '',
        updated: ''
      },
      PaymentBatch: {}
    },
    recurrence_size: 0,
    recurrence_unit: '',
    status: '',
    time_end: '',
    time_start: ''
  },
  status: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    entries: [
      {
        alias: {
          avatar: {
            anchor_uuid: '',
            image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
            style: '',
            uuid: ''
          },
          bunq_me: {name: '', service: '', type: '', value: ''},
          country: '',
          display_name: '',
          iban: '',
          is_light: false,
          label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
          merchant_category_code: '',
          swift_account_number: '',
          swift_bic: '',
          transferwise_account_number: '',
          transferwise_bank_code: ''
        },
        amount: {currency: '', value: ''},
        attachment: [{id: 0, monetary_account_id: 0}],
        counterparty_alias: {},
        description: '',
        id: 0,
        merchant_reference: '',
        type: ''
      }
    ],
    number_of_required_accepts: 0,
    previous_updated_timestamp: '',
    schedule: {
      object: {
        Payment: {
          address_billing: {
            city: '',
            country: '',
            extra: '',
            house_number: '',
            is_user_address_updated: false,
            mailbox_name: '',
            po_box: '',
            postal_code: '',
            province: '',
            street: ''
          },
          address_shipping: {},
          alias: {},
          allow_bunqto: false,
          amount: {},
          attachment: [{}],
          balance_after_mutation: {},
          batch_id: 0,
          bunqto_expiry: '',
          bunqto_share_url: '',
          bunqto_status: '',
          bunqto_sub_status: '',
          bunqto_time_responded: '',
          counterparty_alias: {},
          created: '',
          description: '',
          geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
          id: 0,
          merchant_reference: '',
          monetary_account_id: 0,
          payment_auto_allocate_instance: {
            created: '',
            error_message: [],
            id: 0,
            payment_auto_allocate_id: 0,
            payment_batch: {payments: {Payment: []}},
            payment_id: 0,
            status: '',
            updated: ''
          },
          request_reference_split_the_bill: [{id: 0, type: ''}],
          scheduled_id: 0,
          sub_type: '',
          type: '',
          updated: ''
        },
        PaymentBatch: {}
      },
      recurrence_size: 0,
      recurrence_unit: '',
      status: '',
      time_end: '',
      time_start: ''
    },
    status: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"entries":[{"alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"amount":{"currency":"","value":""},"attachment":[{"id":0,"monetary_account_id":0}],"counterparty_alias":{},"description":"","id":0,"merchant_reference":"","type":""}],"number_of_required_accepts":0,"previous_updated_timestamp":"","schedule":{"object":{"Payment":{"address_billing":{"city":"","country":"","extra":"","house_number":"","is_user_address_updated":false,"mailbox_name":"","po_box":"","postal_code":"","province":"","street":""},"address_shipping":{},"alias":{},"allow_bunqto":false,"amount":{},"attachment":[{}],"balance_after_mutation":{},"batch_id":0,"bunqto_expiry":"","bunqto_share_url":"","bunqto_status":"","bunqto_sub_status":"","bunqto_time_responded":"","counterparty_alias":{},"created":"","description":"","geolocation":{"altitude":0,"latitude":0,"longitude":0,"radius":0},"id":0,"merchant_reference":"","monetary_account_id":0,"payment_auto_allocate_instance":{"created":"","error_message":[],"id":0,"payment_auto_allocate_id":0,"payment_batch":{"payments":{"Payment":[]}},"payment_id":0,"status":"","updated":""},"request_reference_split_the_bill":[{"id":0,"type":""}],"scheduled_id":0,"sub_type":"","type":"","updated":""},"PaymentBatch":{}},"recurrence_size":0,"recurrence_unit":"","status":"","time_end":"","time_start":""},"status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "entries": [\n    {\n      "alias": {\n        "avatar": {\n          "anchor_uuid": "",\n          "image": [\n            {\n              "attachment_public_uuid": "",\n              "content_type": "",\n              "height": 0,\n              "width": 0\n            }\n          ],\n          "style": "",\n          "uuid": ""\n        },\n        "bunq_me": {\n          "name": "",\n          "service": "",\n          "type": "",\n          "value": ""\n        },\n        "country": "",\n        "display_name": "",\n        "iban": "",\n        "is_light": false,\n        "label_user": {\n          "avatar": {},\n          "country": "",\n          "display_name": "",\n          "public_nick_name": "",\n          "uuid": ""\n        },\n        "merchant_category_code": "",\n        "swift_account_number": "",\n        "swift_bic": "",\n        "transferwise_account_number": "",\n        "transferwise_bank_code": ""\n      },\n      "amount": {\n        "currency": "",\n        "value": ""\n      },\n      "attachment": [\n        {\n          "id": 0,\n          "monetary_account_id": 0\n        }\n      ],\n      "counterparty_alias": {},\n      "description": "",\n      "id": 0,\n      "merchant_reference": "",\n      "type": ""\n    }\n  ],\n  "number_of_required_accepts": 0,\n  "previous_updated_timestamp": "",\n  "schedule": {\n    "object": {\n      "Payment": {\n        "address_billing": {\n          "city": "",\n          "country": "",\n          "extra": "",\n          "house_number": "",\n          "is_user_address_updated": false,\n          "mailbox_name": "",\n          "po_box": "",\n          "postal_code": "",\n          "province": "",\n          "street": ""\n        },\n        "address_shipping": {},\n        "alias": {},\n        "allow_bunqto": false,\n        "amount": {},\n        "attachment": [\n          {}\n        ],\n        "balance_after_mutation": {},\n        "batch_id": 0,\n        "bunqto_expiry": "",\n        "bunqto_share_url": "",\n        "bunqto_status": "",\n        "bunqto_sub_status": "",\n        "bunqto_time_responded": "",\n        "counterparty_alias": {},\n        "created": "",\n        "description": "",\n        "geolocation": {\n          "altitude": 0,\n          "latitude": 0,\n          "longitude": 0,\n          "radius": 0\n        },\n        "id": 0,\n        "merchant_reference": "",\n        "monetary_account_id": 0,\n        "payment_auto_allocate_instance": {\n          "created": "",\n          "error_message": [],\n          "id": 0,\n          "payment_auto_allocate_id": 0,\n          "payment_batch": {\n            "payments": {\n              "Payment": []\n            }\n          },\n          "payment_id": 0,\n          "status": "",\n          "updated": ""\n        },\n        "request_reference_split_the_bill": [\n          {\n            "id": 0,\n            "type": ""\n          }\n        ],\n        "scheduled_id": 0,\n        "sub_type": "",\n        "type": "",\n        "updated": ""\n      },\n      "PaymentBatch": {}\n    },\n    "recurrence_size": 0,\n    "recurrence_unit": "",\n    "status": "",\n    "time_end": "",\n    "time_start": ""\n  },\n  "status": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"entries\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"number_of_required_accepts\": 0,\n  \"previous_updated_timestamp\": \"\",\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  entries: [
    {
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
          style: '',
          uuid: ''
        },
        bunq_me: {name: '', service: '', type: '', value: ''},
        country: '',
        display_name: '',
        iban: '',
        is_light: false,
        label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
        merchant_category_code: '',
        swift_account_number: '',
        swift_bic: '',
        transferwise_account_number: '',
        transferwise_bank_code: ''
      },
      amount: {currency: '', value: ''},
      attachment: [{id: 0, monetary_account_id: 0}],
      counterparty_alias: {},
      description: '',
      id: 0,
      merchant_reference: '',
      type: ''
    }
  ],
  number_of_required_accepts: 0,
  previous_updated_timestamp: '',
  schedule: {
    object: {
      Payment: {
        address_billing: {
          city: '',
          country: '',
          extra: '',
          house_number: '',
          is_user_address_updated: false,
          mailbox_name: '',
          po_box: '',
          postal_code: '',
          province: '',
          street: ''
        },
        address_shipping: {},
        alias: {},
        allow_bunqto: false,
        amount: {},
        attachment: [{}],
        balance_after_mutation: {},
        batch_id: 0,
        bunqto_expiry: '',
        bunqto_share_url: '',
        bunqto_status: '',
        bunqto_sub_status: '',
        bunqto_time_responded: '',
        counterparty_alias: {},
        created: '',
        description: '',
        geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
        id: 0,
        merchant_reference: '',
        monetary_account_id: 0,
        payment_auto_allocate_instance: {
          created: '',
          error_message: [],
          id: 0,
          payment_auto_allocate_id: 0,
          payment_batch: {payments: {Payment: []}},
          payment_id: 0,
          status: '',
          updated: ''
        },
        request_reference_split_the_bill: [{id: 0, type: ''}],
        scheduled_id: 0,
        sub_type: '',
        type: '',
        updated: ''
      },
      PaymentBatch: {}
    },
    recurrence_size: 0,
    recurrence_unit: '',
    status: '',
    time_end: '',
    time_start: ''
  },
  status: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    entries: [
      {
        alias: {
          avatar: {
            anchor_uuid: '',
            image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
            style: '',
            uuid: ''
          },
          bunq_me: {name: '', service: '', type: '', value: ''},
          country: '',
          display_name: '',
          iban: '',
          is_light: false,
          label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
          merchant_category_code: '',
          swift_account_number: '',
          swift_bic: '',
          transferwise_account_number: '',
          transferwise_bank_code: ''
        },
        amount: {currency: '', value: ''},
        attachment: [{id: 0, monetary_account_id: 0}],
        counterparty_alias: {},
        description: '',
        id: 0,
        merchant_reference: '',
        type: ''
      }
    ],
    number_of_required_accepts: 0,
    previous_updated_timestamp: '',
    schedule: {
      object: {
        Payment: {
          address_billing: {
            city: '',
            country: '',
            extra: '',
            house_number: '',
            is_user_address_updated: false,
            mailbox_name: '',
            po_box: '',
            postal_code: '',
            province: '',
            street: ''
          },
          address_shipping: {},
          alias: {},
          allow_bunqto: false,
          amount: {},
          attachment: [{}],
          balance_after_mutation: {},
          batch_id: 0,
          bunqto_expiry: '',
          bunqto_share_url: '',
          bunqto_status: '',
          bunqto_sub_status: '',
          bunqto_time_responded: '',
          counterparty_alias: {},
          created: '',
          description: '',
          geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
          id: 0,
          merchant_reference: '',
          monetary_account_id: 0,
          payment_auto_allocate_instance: {
            created: '',
            error_message: [],
            id: 0,
            payment_auto_allocate_id: 0,
            payment_batch: {payments: {Payment: []}},
            payment_id: 0,
            status: '',
            updated: ''
          },
          request_reference_split_the_bill: [{id: 0, type: ''}],
          scheduled_id: 0,
          sub_type: '',
          type: '',
          updated: ''
        },
        PaymentBatch: {}
      },
      recurrence_size: 0,
      recurrence_unit: '',
      status: '',
      time_end: '',
      time_start: ''
    },
    status: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  entries: [
    {
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [
            {
              attachment_public_uuid: '',
              content_type: '',
              height: 0,
              width: 0
            }
          ],
          style: '',
          uuid: ''
        },
        bunq_me: {
          name: '',
          service: '',
          type: '',
          value: ''
        },
        country: '',
        display_name: '',
        iban: '',
        is_light: false,
        label_user: {
          avatar: {},
          country: '',
          display_name: '',
          public_nick_name: '',
          uuid: ''
        },
        merchant_category_code: '',
        swift_account_number: '',
        swift_bic: '',
        transferwise_account_number: '',
        transferwise_bank_code: ''
      },
      amount: {
        currency: '',
        value: ''
      },
      attachment: [
        {
          id: 0,
          monetary_account_id: 0
        }
      ],
      counterparty_alias: {},
      description: '',
      id: 0,
      merchant_reference: '',
      type: ''
    }
  ],
  number_of_required_accepts: 0,
  previous_updated_timestamp: '',
  schedule: {
    object: {
      Payment: {
        address_billing: {
          city: '',
          country: '',
          extra: '',
          house_number: '',
          is_user_address_updated: false,
          mailbox_name: '',
          po_box: '',
          postal_code: '',
          province: '',
          street: ''
        },
        address_shipping: {},
        alias: {},
        allow_bunqto: false,
        amount: {},
        attachment: [
          {}
        ],
        balance_after_mutation: {},
        batch_id: 0,
        bunqto_expiry: '',
        bunqto_share_url: '',
        bunqto_status: '',
        bunqto_sub_status: '',
        bunqto_time_responded: '',
        counterparty_alias: {},
        created: '',
        description: '',
        geolocation: {
          altitude: 0,
          latitude: 0,
          longitude: 0,
          radius: 0
        },
        id: 0,
        merchant_reference: '',
        monetary_account_id: 0,
        payment_auto_allocate_instance: {
          created: '',
          error_message: [],
          id: 0,
          payment_auto_allocate_id: 0,
          payment_batch: {
            payments: {
              Payment: []
            }
          },
          payment_id: 0,
          status: '',
          updated: ''
        },
        request_reference_split_the_bill: [
          {
            id: 0,
            type: ''
          }
        ],
        scheduled_id: 0,
        sub_type: '',
        type: '',
        updated: ''
      },
      PaymentBatch: {}
    },
    recurrence_size: 0,
    recurrence_unit: '',
    status: '',
    time_end: '',
    time_start: ''
  },
  status: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    entries: [
      {
        alias: {
          avatar: {
            anchor_uuid: '',
            image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
            style: '',
            uuid: ''
          },
          bunq_me: {name: '', service: '', type: '', value: ''},
          country: '',
          display_name: '',
          iban: '',
          is_light: false,
          label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
          merchant_category_code: '',
          swift_account_number: '',
          swift_bic: '',
          transferwise_account_number: '',
          transferwise_bank_code: ''
        },
        amount: {currency: '', value: ''},
        attachment: [{id: 0, monetary_account_id: 0}],
        counterparty_alias: {},
        description: '',
        id: 0,
        merchant_reference: '',
        type: ''
      }
    ],
    number_of_required_accepts: 0,
    previous_updated_timestamp: '',
    schedule: {
      object: {
        Payment: {
          address_billing: {
            city: '',
            country: '',
            extra: '',
            house_number: '',
            is_user_address_updated: false,
            mailbox_name: '',
            po_box: '',
            postal_code: '',
            province: '',
            street: ''
          },
          address_shipping: {},
          alias: {},
          allow_bunqto: false,
          amount: {},
          attachment: [{}],
          balance_after_mutation: {},
          batch_id: 0,
          bunqto_expiry: '',
          bunqto_share_url: '',
          bunqto_status: '',
          bunqto_sub_status: '',
          bunqto_time_responded: '',
          counterparty_alias: {},
          created: '',
          description: '',
          geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
          id: 0,
          merchant_reference: '',
          monetary_account_id: 0,
          payment_auto_allocate_instance: {
            created: '',
            error_message: [],
            id: 0,
            payment_auto_allocate_id: 0,
            payment_batch: {payments: {Payment: []}},
            payment_id: 0,
            status: '',
            updated: ''
          },
          request_reference_split_the_bill: [{id: 0, type: ''}],
          scheduled_id: 0,
          sub_type: '',
          type: '',
          updated: ''
        },
        PaymentBatch: {}
      },
      recurrence_size: 0,
      recurrence_unit: '',
      status: '',
      time_end: '',
      time_start: ''
    },
    status: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"entries":[{"alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"amount":{"currency":"","value":""},"attachment":[{"id":0,"monetary_account_id":0}],"counterparty_alias":{},"description":"","id":0,"merchant_reference":"","type":""}],"number_of_required_accepts":0,"previous_updated_timestamp":"","schedule":{"object":{"Payment":{"address_billing":{"city":"","country":"","extra":"","house_number":"","is_user_address_updated":false,"mailbox_name":"","po_box":"","postal_code":"","province":"","street":""},"address_shipping":{},"alias":{},"allow_bunqto":false,"amount":{},"attachment":[{}],"balance_after_mutation":{},"batch_id":0,"bunqto_expiry":"","bunqto_share_url":"","bunqto_status":"","bunqto_sub_status":"","bunqto_time_responded":"","counterparty_alias":{},"created":"","description":"","geolocation":{"altitude":0,"latitude":0,"longitude":0,"radius":0},"id":0,"merchant_reference":"","monetary_account_id":0,"payment_auto_allocate_instance":{"created":"","error_message":[],"id":0,"payment_auto_allocate_id":0,"payment_batch":{"payments":{"Payment":[]}},"payment_id":0,"status":"","updated":""},"request_reference_split_the_bill":[{"id":0,"type":""}],"scheduled_id":0,"sub_type":"","type":"","updated":""},"PaymentBatch":{}},"recurrence_size":0,"recurrence_unit":"","status":"","time_end":"","time_start":""},"status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"entries": @[ @{ @"alias": @{ @"avatar": @{ @"anchor_uuid": @"", @"image": @[ @{ @"attachment_public_uuid": @"", @"content_type": @"", @"height": @0, @"width": @0 } ], @"style": @"", @"uuid": @"" }, @"bunq_me": @{ @"name": @"", @"service": @"", @"type": @"", @"value": @"" }, @"country": @"", @"display_name": @"", @"iban": @"", @"is_light": @NO, @"label_user": @{ @"avatar": @{  }, @"country": @"", @"display_name": @"", @"public_nick_name": @"", @"uuid": @"" }, @"merchant_category_code": @"", @"swift_account_number": @"", @"swift_bic": @"", @"transferwise_account_number": @"", @"transferwise_bank_code": @"" }, @"amount": @{ @"currency": @"", @"value": @"" }, @"attachment": @[ @{ @"id": @0, @"monetary_account_id": @0 } ], @"counterparty_alias": @{  }, @"description": @"", @"id": @0, @"merchant_reference": @"", @"type": @"" } ],
                              @"number_of_required_accepts": @0,
                              @"previous_updated_timestamp": @"",
                              @"schedule": @{ @"object": @{ @"Payment": @{ @"address_billing": @{ @"city": @"", @"country": @"", @"extra": @"", @"house_number": @"", @"is_user_address_updated": @NO, @"mailbox_name": @"", @"po_box": @"", @"postal_code": @"", @"province": @"", @"street": @"" }, @"address_shipping": @{  }, @"alias": @{  }, @"allow_bunqto": @NO, @"amount": @{  }, @"attachment": @[ @{  } ], @"balance_after_mutation": @{  }, @"batch_id": @0, @"bunqto_expiry": @"", @"bunqto_share_url": @"", @"bunqto_status": @"", @"bunqto_sub_status": @"", @"bunqto_time_responded": @"", @"counterparty_alias": @{  }, @"created": @"", @"description": @"", @"geolocation": @{ @"altitude": @0, @"latitude": @0, @"longitude": @0, @"radius": @0 }, @"id": @0, @"merchant_reference": @"", @"monetary_account_id": @0, @"payment_auto_allocate_instance": @{ @"created": @"", @"error_message": @[  ], @"id": @0, @"payment_auto_allocate_id": @0, @"payment_batch": @{ @"payments": @{ @"Payment": @[  ] } }, @"payment_id": @0, @"status": @"", @"updated": @"" }, @"request_reference_split_the_bill": @[ @{ @"id": @0, @"type": @"" } ], @"scheduled_id": @0, @"sub_type": @"", @"type": @"", @"updated": @"" }, @"PaymentBatch": @{  } }, @"recurrence_size": @0, @"recurrence_unit": @"", @"status": @"", @"time_end": @"", @"time_start": @"" },
                              @"status": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"entries\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"number_of_required_accepts\": 0,\n  \"previous_updated_timestamp\": \"\",\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'entries' => [
        [
                'alias' => [
                                'avatar' => [
                                                                'anchor_uuid' => '',
                                                                'image' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'attachment_public_uuid' => '',
                                                                                                                                                                                                                                                                'content_type' => '',
                                                                                                                                                                                                                                                                'height' => 0,
                                                                                                                                                                                                                                                                'width' => 0
                                                                                                                                ]
                                                                ],
                                                                'style' => '',
                                                                'uuid' => ''
                                ],
                                'bunq_me' => [
                                                                'name' => '',
                                                                'service' => '',
                                                                'type' => '',
                                                                'value' => ''
                                ],
                                'country' => '',
                                'display_name' => '',
                                'iban' => '',
                                'is_light' => null,
                                'label_user' => [
                                                                'avatar' => [
                                                                                                                                
                                                                ],
                                                                'country' => '',
                                                                'display_name' => '',
                                                                'public_nick_name' => '',
                                                                'uuid' => ''
                                ],
                                'merchant_category_code' => '',
                                'swift_account_number' => '',
                                'swift_bic' => '',
                                'transferwise_account_number' => '',
                                'transferwise_bank_code' => ''
                ],
                'amount' => [
                                'currency' => '',
                                'value' => ''
                ],
                'attachment' => [
                                [
                                                                'id' => 0,
                                                                'monetary_account_id' => 0
                                ]
                ],
                'counterparty_alias' => [
                                
                ],
                'description' => '',
                'id' => 0,
                'merchant_reference' => '',
                'type' => ''
        ]
    ],
    'number_of_required_accepts' => 0,
    'previous_updated_timestamp' => '',
    'schedule' => [
        'object' => [
                'Payment' => [
                                'address_billing' => [
                                                                'city' => '',
                                                                'country' => '',
                                                                'extra' => '',
                                                                'house_number' => '',
                                                                'is_user_address_updated' => null,
                                                                'mailbox_name' => '',
                                                                'po_box' => '',
                                                                'postal_code' => '',
                                                                'province' => '',
                                                                'street' => ''
                                ],
                                'address_shipping' => [
                                                                
                                ],
                                'alias' => [
                                                                
                                ],
                                'allow_bunqto' => null,
                                'amount' => [
                                                                
                                ],
                                'attachment' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'balance_after_mutation' => [
                                                                
                                ],
                                'batch_id' => 0,
                                'bunqto_expiry' => '',
                                'bunqto_share_url' => '',
                                'bunqto_status' => '',
                                'bunqto_sub_status' => '',
                                'bunqto_time_responded' => '',
                                'counterparty_alias' => [
                                                                
                                ],
                                'created' => '',
                                'description' => '',
                                'geolocation' => [
                                                                'altitude' => 0,
                                                                'latitude' => 0,
                                                                'longitude' => 0,
                                                                'radius' => 0
                                ],
                                'id' => 0,
                                'merchant_reference' => '',
                                'monetary_account_id' => 0,
                                'payment_auto_allocate_instance' => [
                                                                'created' => '',
                                                                'error_message' => [
                                                                                                                                
                                                                ],
                                                                'id' => 0,
                                                                'payment_auto_allocate_id' => 0,
                                                                'payment_batch' => [
                                                                                                                                'payments' => [
                                                                                                                                                                                                                                                                'Payment' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ]
                                                                                                                                ]
                                                                ],
                                                                'payment_id' => 0,
                                                                'status' => '',
                                                                'updated' => ''
                                ],
                                'request_reference_split_the_bill' => [
                                                                [
                                                                                                                                'id' => 0,
                                                                                                                                'type' => ''
                                                                ]
                                ],
                                'scheduled_id' => 0,
                                'sub_type' => '',
                                'type' => '',
                                'updated' => ''
                ],
                'PaymentBatch' => [
                                
                ]
        ],
        'recurrence_size' => 0,
        'recurrence_unit' => '',
        'status' => '',
        'time_end' => '',
        'time_start' => ''
    ],
    'status' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment', [
  'body' => '{
  "entries": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "counterparty_alias": {},
      "description": "",
      "id": 0,
      "merchant_reference": "",
      "type": ""
    }
  ],
  "number_of_required_accepts": 0,
  "previous_updated_timestamp": "",
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  },
  "status": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'entries' => [
    [
        'alias' => [
                'avatar' => [
                                'anchor_uuid' => '',
                                'image' => [
                                                                [
                                                                                                                                'attachment_public_uuid' => '',
                                                                                                                                'content_type' => '',
                                                                                                                                'height' => 0,
                                                                                                                                'width' => 0
                                                                ]
                                ],
                                'style' => '',
                                'uuid' => ''
                ],
                'bunq_me' => [
                                'name' => '',
                                'service' => '',
                                'type' => '',
                                'value' => ''
                ],
                'country' => '',
                'display_name' => '',
                'iban' => '',
                'is_light' => null,
                'label_user' => [
                                'avatar' => [
                                                                
                                ],
                                'country' => '',
                                'display_name' => '',
                                'public_nick_name' => '',
                                'uuid' => ''
                ],
                'merchant_category_code' => '',
                'swift_account_number' => '',
                'swift_bic' => '',
                'transferwise_account_number' => '',
                'transferwise_bank_code' => ''
        ],
        'amount' => [
                'currency' => '',
                'value' => ''
        ],
        'attachment' => [
                [
                                'id' => 0,
                                'monetary_account_id' => 0
                ]
        ],
        'counterparty_alias' => [
                
        ],
        'description' => '',
        'id' => 0,
        'merchant_reference' => '',
        'type' => ''
    ]
  ],
  'number_of_required_accepts' => 0,
  'previous_updated_timestamp' => '',
  'schedule' => [
    'object' => [
        'Payment' => [
                'address_billing' => [
                                'city' => '',
                                'country' => '',
                                'extra' => '',
                                'house_number' => '',
                                'is_user_address_updated' => null,
                                'mailbox_name' => '',
                                'po_box' => '',
                                'postal_code' => '',
                                'province' => '',
                                'street' => ''
                ],
                'address_shipping' => [
                                
                ],
                'alias' => [
                                
                ],
                'allow_bunqto' => null,
                'amount' => [
                                
                ],
                'attachment' => [
                                [
                                                                
                                ]
                ],
                'balance_after_mutation' => [
                                
                ],
                'batch_id' => 0,
                'bunqto_expiry' => '',
                'bunqto_share_url' => '',
                'bunqto_status' => '',
                'bunqto_sub_status' => '',
                'bunqto_time_responded' => '',
                'counterparty_alias' => [
                                
                ],
                'created' => '',
                'description' => '',
                'geolocation' => [
                                'altitude' => 0,
                                'latitude' => 0,
                                'longitude' => 0,
                                'radius' => 0
                ],
                'id' => 0,
                'merchant_reference' => '',
                'monetary_account_id' => 0,
                'payment_auto_allocate_instance' => [
                                'created' => '',
                                'error_message' => [
                                                                
                                ],
                                'id' => 0,
                                'payment_auto_allocate_id' => 0,
                                'payment_batch' => [
                                                                'payments' => [
                                                                                                                                'Payment' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'payment_id' => 0,
                                'status' => '',
                                'updated' => ''
                ],
                'request_reference_split_the_bill' => [
                                [
                                                                'id' => 0,
                                                                'type' => ''
                                ]
                ],
                'scheduled_id' => 0,
                'sub_type' => '',
                'type' => '',
                'updated' => ''
        ],
        'PaymentBatch' => [
                
        ]
    ],
    'recurrence_size' => 0,
    'recurrence_unit' => '',
    'status' => '',
    'time_end' => '',
    'time_start' => ''
  ],
  'status' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'entries' => [
    [
        'alias' => [
                'avatar' => [
                                'anchor_uuid' => '',
                                'image' => [
                                                                [
                                                                                                                                'attachment_public_uuid' => '',
                                                                                                                                'content_type' => '',
                                                                                                                                'height' => 0,
                                                                                                                                'width' => 0
                                                                ]
                                ],
                                'style' => '',
                                'uuid' => ''
                ],
                'bunq_me' => [
                                'name' => '',
                                'service' => '',
                                'type' => '',
                                'value' => ''
                ],
                'country' => '',
                'display_name' => '',
                'iban' => '',
                'is_light' => null,
                'label_user' => [
                                'avatar' => [
                                                                
                                ],
                                'country' => '',
                                'display_name' => '',
                                'public_nick_name' => '',
                                'uuid' => ''
                ],
                'merchant_category_code' => '',
                'swift_account_number' => '',
                'swift_bic' => '',
                'transferwise_account_number' => '',
                'transferwise_bank_code' => ''
        ],
        'amount' => [
                'currency' => '',
                'value' => ''
        ],
        'attachment' => [
                [
                                'id' => 0,
                                'monetary_account_id' => 0
                ]
        ],
        'counterparty_alias' => [
                
        ],
        'description' => '',
        'id' => 0,
        'merchant_reference' => '',
        'type' => ''
    ]
  ],
  'number_of_required_accepts' => 0,
  'previous_updated_timestamp' => '',
  'schedule' => [
    'object' => [
        'Payment' => [
                'address_billing' => [
                                'city' => '',
                                'country' => '',
                                'extra' => '',
                                'house_number' => '',
                                'is_user_address_updated' => null,
                                'mailbox_name' => '',
                                'po_box' => '',
                                'postal_code' => '',
                                'province' => '',
                                'street' => ''
                ],
                'address_shipping' => [
                                
                ],
                'alias' => [
                                
                ],
                'allow_bunqto' => null,
                'amount' => [
                                
                ],
                'attachment' => [
                                [
                                                                
                                ]
                ],
                'balance_after_mutation' => [
                                
                ],
                'batch_id' => 0,
                'bunqto_expiry' => '',
                'bunqto_share_url' => '',
                'bunqto_status' => '',
                'bunqto_sub_status' => '',
                'bunqto_time_responded' => '',
                'counterparty_alias' => [
                                
                ],
                'created' => '',
                'description' => '',
                'geolocation' => [
                                'altitude' => 0,
                                'latitude' => 0,
                                'longitude' => 0,
                                'radius' => 0
                ],
                'id' => 0,
                'merchant_reference' => '',
                'monetary_account_id' => 0,
                'payment_auto_allocate_instance' => [
                                'created' => '',
                                'error_message' => [
                                                                
                                ],
                                'id' => 0,
                                'payment_auto_allocate_id' => 0,
                                'payment_batch' => [
                                                                'payments' => [
                                                                                                                                'Payment' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'payment_id' => 0,
                                'status' => '',
                                'updated' => ''
                ],
                'request_reference_split_the_bill' => [
                                [
                                                                'id' => 0,
                                                                'type' => ''
                                ]
                ],
                'scheduled_id' => 0,
                'sub_type' => '',
                'type' => '',
                'updated' => ''
        ],
        'PaymentBatch' => [
                
        ]
    ],
    'recurrence_size' => 0,
    'recurrence_unit' => '',
    'status' => '',
    'time_end' => '',
    'time_start' => ''
  ],
  'status' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "entries": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "counterparty_alias": {},
      "description": "",
      "id": 0,
      "merchant_reference": "",
      "type": ""
    }
  ],
  "number_of_required_accepts": 0,
  "previous_updated_timestamp": "",
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  },
  "status": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "entries": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "counterparty_alias": {},
      "description": "",
      "id": 0,
      "merchant_reference": "",
      "type": ""
    }
  ],
  "number_of_required_accepts": 0,
  "previous_updated_timestamp": "",
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  },
  "status": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"entries\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"number_of_required_accepts\": 0,\n  \"previous_updated_timestamp\": \"\",\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment"

payload = {
    "entries": [
        {
            "alias": {
                "avatar": {
                    "anchor_uuid": "",
                    "image": [
                        {
                            "attachment_public_uuid": "",
                            "content_type": "",
                            "height": 0,
                            "width": 0
                        }
                    ],
                    "style": "",
                    "uuid": ""
                },
                "bunq_me": {
                    "name": "",
                    "service": "",
                    "type": "",
                    "value": ""
                },
                "country": "",
                "display_name": "",
                "iban": "",
                "is_light": False,
                "label_user": {
                    "avatar": {},
                    "country": "",
                    "display_name": "",
                    "public_nick_name": "",
                    "uuid": ""
                },
                "merchant_category_code": "",
                "swift_account_number": "",
                "swift_bic": "",
                "transferwise_account_number": "",
                "transferwise_bank_code": ""
            },
            "amount": {
                "currency": "",
                "value": ""
            },
            "attachment": [
                {
                    "id": 0,
                    "monetary_account_id": 0
                }
            ],
            "counterparty_alias": {},
            "description": "",
            "id": 0,
            "merchant_reference": "",
            "type": ""
        }
    ],
    "number_of_required_accepts": 0,
    "previous_updated_timestamp": "",
    "schedule": {
        "object": {
            "Payment": {
                "address_billing": {
                    "city": "",
                    "country": "",
                    "extra": "",
                    "house_number": "",
                    "is_user_address_updated": False,
                    "mailbox_name": "",
                    "po_box": "",
                    "postal_code": "",
                    "province": "",
                    "street": ""
                },
                "address_shipping": {},
                "alias": {},
                "allow_bunqto": False,
                "amount": {},
                "attachment": [{}],
                "balance_after_mutation": {},
                "batch_id": 0,
                "bunqto_expiry": "",
                "bunqto_share_url": "",
                "bunqto_status": "",
                "bunqto_sub_status": "",
                "bunqto_time_responded": "",
                "counterparty_alias": {},
                "created": "",
                "description": "",
                "geolocation": {
                    "altitude": 0,
                    "latitude": 0,
                    "longitude": 0,
                    "radius": 0
                },
                "id": 0,
                "merchant_reference": "",
                "monetary_account_id": 0,
                "payment_auto_allocate_instance": {
                    "created": "",
                    "error_message": [],
                    "id": 0,
                    "payment_auto_allocate_id": 0,
                    "payment_batch": { "payments": { "Payment": [] } },
                    "payment_id": 0,
                    "status": "",
                    "updated": ""
                },
                "request_reference_split_the_bill": [
                    {
                        "id": 0,
                        "type": ""
                    }
                ],
                "scheduled_id": 0,
                "sub_type": "",
                "type": "",
                "updated": ""
            },
            "PaymentBatch": {}
        },
        "recurrence_size": 0,
        "recurrence_unit": "",
        "status": "",
        "time_end": "",
        "time_start": ""
    },
    "status": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment"

payload <- "{\n  \"entries\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"number_of_required_accepts\": 0,\n  \"previous_updated_timestamp\": \"\",\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"entries\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"number_of_required_accepts\": 0,\n  \"previous_updated_timestamp\": \"\",\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"entries\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"number_of_required_accepts\": 0,\n  \"previous_updated_timestamp\": \"\",\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment";

    let payload = json!({
        "entries": (
            json!({
                "alias": json!({
                    "avatar": json!({
                        "anchor_uuid": "",
                        "image": (
                            json!({
                                "attachment_public_uuid": "",
                                "content_type": "",
                                "height": 0,
                                "width": 0
                            })
                        ),
                        "style": "",
                        "uuid": ""
                    }),
                    "bunq_me": json!({
                        "name": "",
                        "service": "",
                        "type": "",
                        "value": ""
                    }),
                    "country": "",
                    "display_name": "",
                    "iban": "",
                    "is_light": false,
                    "label_user": json!({
                        "avatar": json!({}),
                        "country": "",
                        "display_name": "",
                        "public_nick_name": "",
                        "uuid": ""
                    }),
                    "merchant_category_code": "",
                    "swift_account_number": "",
                    "swift_bic": "",
                    "transferwise_account_number": "",
                    "transferwise_bank_code": ""
                }),
                "amount": json!({
                    "currency": "",
                    "value": ""
                }),
                "attachment": (
                    json!({
                        "id": 0,
                        "monetary_account_id": 0
                    })
                ),
                "counterparty_alias": json!({}),
                "description": "",
                "id": 0,
                "merchant_reference": "",
                "type": ""
            })
        ),
        "number_of_required_accepts": 0,
        "previous_updated_timestamp": "",
        "schedule": json!({
            "object": json!({
                "Payment": json!({
                    "address_billing": json!({
                        "city": "",
                        "country": "",
                        "extra": "",
                        "house_number": "",
                        "is_user_address_updated": false,
                        "mailbox_name": "",
                        "po_box": "",
                        "postal_code": "",
                        "province": "",
                        "street": ""
                    }),
                    "address_shipping": json!({}),
                    "alias": json!({}),
                    "allow_bunqto": false,
                    "amount": json!({}),
                    "attachment": (json!({})),
                    "balance_after_mutation": json!({}),
                    "batch_id": 0,
                    "bunqto_expiry": "",
                    "bunqto_share_url": "",
                    "bunqto_status": "",
                    "bunqto_sub_status": "",
                    "bunqto_time_responded": "",
                    "counterparty_alias": json!({}),
                    "created": "",
                    "description": "",
                    "geolocation": json!({
                        "altitude": 0,
                        "latitude": 0,
                        "longitude": 0,
                        "radius": 0
                    }),
                    "id": 0,
                    "merchant_reference": "",
                    "monetary_account_id": 0,
                    "payment_auto_allocate_instance": json!({
                        "created": "",
                        "error_message": (),
                        "id": 0,
                        "payment_auto_allocate_id": 0,
                        "payment_batch": json!({"payments": json!({"Payment": ()})}),
                        "payment_id": 0,
                        "status": "",
                        "updated": ""
                    }),
                    "request_reference_split_the_bill": (
                        json!({
                            "id": 0,
                            "type": ""
                        })
                    ),
                    "scheduled_id": 0,
                    "sub_type": "",
                    "type": "",
                    "updated": ""
                }),
                "PaymentBatch": json!({})
            }),
            "recurrence_size": 0,
            "recurrence_unit": "",
            "status": "",
            "time_end": "",
            "time_start": ""
        }),
        "status": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "entries": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "counterparty_alias": {},
      "description": "",
      "id": 0,
      "merchant_reference": "",
      "type": ""
    }
  ],
  "number_of_required_accepts": 0,
  "previous_updated_timestamp": "",
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  },
  "status": ""
}'
echo '{
  "entries": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "counterparty_alias": {},
      "description": "",
      "id": 0,
      "merchant_reference": "",
      "type": ""
    }
  ],
  "number_of_required_accepts": 0,
  "previous_updated_timestamp": "",
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  },
  "status": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "entries": [\n    {\n      "alias": {\n        "avatar": {\n          "anchor_uuid": "",\n          "image": [\n            {\n              "attachment_public_uuid": "",\n              "content_type": "",\n              "height": 0,\n              "width": 0\n            }\n          ],\n          "style": "",\n          "uuid": ""\n        },\n        "bunq_me": {\n          "name": "",\n          "service": "",\n          "type": "",\n          "value": ""\n        },\n        "country": "",\n        "display_name": "",\n        "iban": "",\n        "is_light": false,\n        "label_user": {\n          "avatar": {},\n          "country": "",\n          "display_name": "",\n          "public_nick_name": "",\n          "uuid": ""\n        },\n        "merchant_category_code": "",\n        "swift_account_number": "",\n        "swift_bic": "",\n        "transferwise_account_number": "",\n        "transferwise_bank_code": ""\n      },\n      "amount": {\n        "currency": "",\n        "value": ""\n      },\n      "attachment": [\n        {\n          "id": 0,\n          "monetary_account_id": 0\n        }\n      ],\n      "counterparty_alias": {},\n      "description": "",\n      "id": 0,\n      "merchant_reference": "",\n      "type": ""\n    }\n  ],\n  "number_of_required_accepts": 0,\n  "previous_updated_timestamp": "",\n  "schedule": {\n    "object": {\n      "Payment": {\n        "address_billing": {\n          "city": "",\n          "country": "",\n          "extra": "",\n          "house_number": "",\n          "is_user_address_updated": false,\n          "mailbox_name": "",\n          "po_box": "",\n          "postal_code": "",\n          "province": "",\n          "street": ""\n        },\n        "address_shipping": {},\n        "alias": {},\n        "allow_bunqto": false,\n        "amount": {},\n        "attachment": [\n          {}\n        ],\n        "balance_after_mutation": {},\n        "batch_id": 0,\n        "bunqto_expiry": "",\n        "bunqto_share_url": "",\n        "bunqto_status": "",\n        "bunqto_sub_status": "",\n        "bunqto_time_responded": "",\n        "counterparty_alias": {},\n        "created": "",\n        "description": "",\n        "geolocation": {\n          "altitude": 0,\n          "latitude": 0,\n          "longitude": 0,\n          "radius": 0\n        },\n        "id": 0,\n        "merchant_reference": "",\n        "monetary_account_id": 0,\n        "payment_auto_allocate_instance": {\n          "created": "",\n          "error_message": [],\n          "id": 0,\n          "payment_auto_allocate_id": 0,\n          "payment_batch": {\n            "payments": {\n              "Payment": []\n            }\n          },\n          "payment_id": 0,\n          "status": "",\n          "updated": ""\n        },\n        "request_reference_split_the_bill": [\n          {\n            "id": 0,\n            "type": ""\n          }\n        ],\n        "scheduled_id": 0,\n        "sub_type": "",\n        "type": "",\n        "updated": ""\n      },\n      "PaymentBatch": {}\n    },\n    "recurrence_size": 0,\n    "recurrence_unit": "",\n    "status": "",\n    "time_end": "",\n    "time_start": ""\n  },\n  "status": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "entries": [
    [
      "alias": [
        "avatar": [
          "anchor_uuid": "",
          "image": [
            [
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            ]
          ],
          "style": "",
          "uuid": ""
        ],
        "bunq_me": [
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        ],
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": [
          "avatar": [],
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        ],
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      ],
      "amount": [
        "currency": "",
        "value": ""
      ],
      "attachment": [
        [
          "id": 0,
          "monetary_account_id": 0
        ]
      ],
      "counterparty_alias": [],
      "description": "",
      "id": 0,
      "merchant_reference": "",
      "type": ""
    ]
  ],
  "number_of_required_accepts": 0,
  "previous_updated_timestamp": "",
  "schedule": [
    "object": [
      "Payment": [
        "address_billing": [
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        ],
        "address_shipping": [],
        "alias": [],
        "allow_bunqto": false,
        "amount": [],
        "attachment": [[]],
        "balance_after_mutation": [],
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": [],
        "created": "",
        "description": "",
        "geolocation": [
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        ],
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": [
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": ["payments": ["Payment": []]],
          "payment_id": 0,
          "status": "",
          "updated": ""
        ],
        "request_reference_split_the_bill": [
          [
            "id": 0,
            "type": ""
          ]
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      ],
      "PaymentBatch": []
    ],
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  ],
  "status": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_DraftPayment_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment" {:headers {:user-agent ""
                                                                                                                     :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_DraftPayment_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId" {:headers {:user-agent ""
                                                                                                                             :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_DraftPayment_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
itemId
BODY json

{
  "entries": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "counterparty_alias": {},
      "description": "",
      "id": 0,
      "merchant_reference": "",
      "type": ""
    }
  ],
  "number_of_required_accepts": 0,
  "previous_updated_timestamp": "",
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  },
  "status": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"entries\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"number_of_required_accepts\": 0,\n  \"previous_updated_timestamp\": \"\",\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId" {:headers {:user-agent ""
                                                                                                                             :x-bunq-client-authentication ""}
                                                                                                                   :content-type :json
                                                                                                                   :form-params {:entries [{:alias {:avatar {:anchor_uuid ""
                                                                                                                                                             :image [{:attachment_public_uuid ""
                                                                                                                                                                      :content_type ""
                                                                                                                                                                      :height 0
                                                                                                                                                                      :width 0}]
                                                                                                                                                             :style ""
                                                                                                                                                             :uuid ""}
                                                                                                                                                    :bunq_me {:name ""
                                                                                                                                                              :service ""
                                                                                                                                                              :type ""
                                                                                                                                                              :value ""}
                                                                                                                                                    :country ""
                                                                                                                                                    :display_name ""
                                                                                                                                                    :iban ""
                                                                                                                                                    :is_light false
                                                                                                                                                    :label_user {:avatar {}
                                                                                                                                                                 :country ""
                                                                                                                                                                 :display_name ""
                                                                                                                                                                 :public_nick_name ""
                                                                                                                                                                 :uuid ""}
                                                                                                                                                    :merchant_category_code ""
                                                                                                                                                    :swift_account_number ""
                                                                                                                                                    :swift_bic ""
                                                                                                                                                    :transferwise_account_number ""
                                                                                                                                                    :transferwise_bank_code ""}
                                                                                                                                            :amount {:currency ""
                                                                                                                                                     :value ""}
                                                                                                                                            :attachment [{:id 0
                                                                                                                                                          :monetary_account_id 0}]
                                                                                                                                            :counterparty_alias {}
                                                                                                                                            :description ""
                                                                                                                                            :id 0
                                                                                                                                            :merchant_reference ""
                                                                                                                                            :type ""}]
                                                                                                                                 :number_of_required_accepts 0
                                                                                                                                 :previous_updated_timestamp ""
                                                                                                                                 :schedule {:object {:Payment {:address_billing {:city ""
                                                                                                                                                                                 :country ""
                                                                                                                                                                                 :extra ""
                                                                                                                                                                                 :house_number ""
                                                                                                                                                                                 :is_user_address_updated false
                                                                                                                                                                                 :mailbox_name ""
                                                                                                                                                                                 :po_box ""
                                                                                                                                                                                 :postal_code ""
                                                                                                                                                                                 :province ""
                                                                                                                                                                                 :street ""}
                                                                                                                                                               :address_shipping {}
                                                                                                                                                               :alias {}
                                                                                                                                                               :allow_bunqto false
                                                                                                                                                               :amount {}
                                                                                                                                                               :attachment [{}]
                                                                                                                                                               :balance_after_mutation {}
                                                                                                                                                               :batch_id 0
                                                                                                                                                               :bunqto_expiry ""
                                                                                                                                                               :bunqto_share_url ""
                                                                                                                                                               :bunqto_status ""
                                                                                                                                                               :bunqto_sub_status ""
                                                                                                                                                               :bunqto_time_responded ""
                                                                                                                                                               :counterparty_alias {}
                                                                                                                                                               :created ""
                                                                                                                                                               :description ""
                                                                                                                                                               :geolocation {:altitude 0
                                                                                                                                                                             :latitude 0
                                                                                                                                                                             :longitude 0
                                                                                                                                                                             :radius 0}
                                                                                                                                                               :id 0
                                                                                                                                                               :merchant_reference ""
                                                                                                                                                               :monetary_account_id 0
                                                                                                                                                               :payment_auto_allocate_instance {:created ""
                                                                                                                                                                                                :error_message []
                                                                                                                                                                                                :id 0
                                                                                                                                                                                                :payment_auto_allocate_id 0
                                                                                                                                                                                                :payment_batch {:payments {:Payment []}}
                                                                                                                                                                                                :payment_id 0
                                                                                                                                                                                                :status ""
                                                                                                                                                                                                :updated ""}
                                                                                                                                                               :request_reference_split_the_bill [{:id 0
                                                                                                                                                                                                   :type ""}]
                                                                                                                                                               :scheduled_id 0
                                                                                                                                                               :sub_type ""
                                                                                                                                                               :type ""
                                                                                                                                                               :updated ""}
                                                                                                                                                     :PaymentBatch {}}
                                                                                                                                            :recurrence_size 0
                                                                                                                                            :recurrence_unit ""
                                                                                                                                            :status ""
                                                                                                                                            :time_end ""
                                                                                                                                            :time_start ""}
                                                                                                                                 :status ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"entries\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"number_of_required_accepts\": 0,\n  \"previous_updated_timestamp\": \"\",\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"entries\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"number_of_required_accepts\": 0,\n  \"previous_updated_timestamp\": \"\",\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"entries\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"number_of_required_accepts\": 0,\n  \"previous_updated_timestamp\": \"\",\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId"

	payload := strings.NewReader("{\n  \"entries\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"number_of_required_accepts\": 0,\n  \"previous_updated_timestamp\": \"\",\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 3086

{
  "entries": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "counterparty_alias": {},
      "description": "",
      "id": 0,
      "merchant_reference": "",
      "type": ""
    }
  ],
  "number_of_required_accepts": 0,
  "previous_updated_timestamp": "",
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  },
  "status": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"entries\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"number_of_required_accepts\": 0,\n  \"previous_updated_timestamp\": \"\",\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"entries\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"number_of_required_accepts\": 0,\n  \"previous_updated_timestamp\": \"\",\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"entries\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"number_of_required_accepts\": 0,\n  \"previous_updated_timestamp\": \"\",\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"entries\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"number_of_required_accepts\": 0,\n  \"previous_updated_timestamp\": \"\",\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  entries: [
    {
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [
            {
              attachment_public_uuid: '',
              content_type: '',
              height: 0,
              width: 0
            }
          ],
          style: '',
          uuid: ''
        },
        bunq_me: {
          name: '',
          service: '',
          type: '',
          value: ''
        },
        country: '',
        display_name: '',
        iban: '',
        is_light: false,
        label_user: {
          avatar: {},
          country: '',
          display_name: '',
          public_nick_name: '',
          uuid: ''
        },
        merchant_category_code: '',
        swift_account_number: '',
        swift_bic: '',
        transferwise_account_number: '',
        transferwise_bank_code: ''
      },
      amount: {
        currency: '',
        value: ''
      },
      attachment: [
        {
          id: 0,
          monetary_account_id: 0
        }
      ],
      counterparty_alias: {},
      description: '',
      id: 0,
      merchant_reference: '',
      type: ''
    }
  ],
  number_of_required_accepts: 0,
  previous_updated_timestamp: '',
  schedule: {
    object: {
      Payment: {
        address_billing: {
          city: '',
          country: '',
          extra: '',
          house_number: '',
          is_user_address_updated: false,
          mailbox_name: '',
          po_box: '',
          postal_code: '',
          province: '',
          street: ''
        },
        address_shipping: {},
        alias: {},
        allow_bunqto: false,
        amount: {},
        attachment: [
          {}
        ],
        balance_after_mutation: {},
        batch_id: 0,
        bunqto_expiry: '',
        bunqto_share_url: '',
        bunqto_status: '',
        bunqto_sub_status: '',
        bunqto_time_responded: '',
        counterparty_alias: {},
        created: '',
        description: '',
        geolocation: {
          altitude: 0,
          latitude: 0,
          longitude: 0,
          radius: 0
        },
        id: 0,
        merchant_reference: '',
        monetary_account_id: 0,
        payment_auto_allocate_instance: {
          created: '',
          error_message: [],
          id: 0,
          payment_auto_allocate_id: 0,
          payment_batch: {
            payments: {
              Payment: []
            }
          },
          payment_id: 0,
          status: '',
          updated: ''
        },
        request_reference_split_the_bill: [
          {
            id: 0,
            type: ''
          }
        ],
        scheduled_id: 0,
        sub_type: '',
        type: '',
        updated: ''
      },
      PaymentBatch: {}
    },
    recurrence_size: 0,
    recurrence_unit: '',
    status: '',
    time_end: '',
    time_start: ''
  },
  status: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    entries: [
      {
        alias: {
          avatar: {
            anchor_uuid: '',
            image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
            style: '',
            uuid: ''
          },
          bunq_me: {name: '', service: '', type: '', value: ''},
          country: '',
          display_name: '',
          iban: '',
          is_light: false,
          label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
          merchant_category_code: '',
          swift_account_number: '',
          swift_bic: '',
          transferwise_account_number: '',
          transferwise_bank_code: ''
        },
        amount: {currency: '', value: ''},
        attachment: [{id: 0, monetary_account_id: 0}],
        counterparty_alias: {},
        description: '',
        id: 0,
        merchant_reference: '',
        type: ''
      }
    ],
    number_of_required_accepts: 0,
    previous_updated_timestamp: '',
    schedule: {
      object: {
        Payment: {
          address_billing: {
            city: '',
            country: '',
            extra: '',
            house_number: '',
            is_user_address_updated: false,
            mailbox_name: '',
            po_box: '',
            postal_code: '',
            province: '',
            street: ''
          },
          address_shipping: {},
          alias: {},
          allow_bunqto: false,
          amount: {},
          attachment: [{}],
          balance_after_mutation: {},
          batch_id: 0,
          bunqto_expiry: '',
          bunqto_share_url: '',
          bunqto_status: '',
          bunqto_sub_status: '',
          bunqto_time_responded: '',
          counterparty_alias: {},
          created: '',
          description: '',
          geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
          id: 0,
          merchant_reference: '',
          monetary_account_id: 0,
          payment_auto_allocate_instance: {
            created: '',
            error_message: [],
            id: 0,
            payment_auto_allocate_id: 0,
            payment_batch: {payments: {Payment: []}},
            payment_id: 0,
            status: '',
            updated: ''
          },
          request_reference_split_the_bill: [{id: 0, type: ''}],
          scheduled_id: 0,
          sub_type: '',
          type: '',
          updated: ''
        },
        PaymentBatch: {}
      },
      recurrence_size: 0,
      recurrence_unit: '',
      status: '',
      time_end: '',
      time_start: ''
    },
    status: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"entries":[{"alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"amount":{"currency":"","value":""},"attachment":[{"id":0,"monetary_account_id":0}],"counterparty_alias":{},"description":"","id":0,"merchant_reference":"","type":""}],"number_of_required_accepts":0,"previous_updated_timestamp":"","schedule":{"object":{"Payment":{"address_billing":{"city":"","country":"","extra":"","house_number":"","is_user_address_updated":false,"mailbox_name":"","po_box":"","postal_code":"","province":"","street":""},"address_shipping":{},"alias":{},"allow_bunqto":false,"amount":{},"attachment":[{}],"balance_after_mutation":{},"batch_id":0,"bunqto_expiry":"","bunqto_share_url":"","bunqto_status":"","bunqto_sub_status":"","bunqto_time_responded":"","counterparty_alias":{},"created":"","description":"","geolocation":{"altitude":0,"latitude":0,"longitude":0,"radius":0},"id":0,"merchant_reference":"","monetary_account_id":0,"payment_auto_allocate_instance":{"created":"","error_message":[],"id":0,"payment_auto_allocate_id":0,"payment_batch":{"payments":{"Payment":[]}},"payment_id":0,"status":"","updated":""},"request_reference_split_the_bill":[{"id":0,"type":""}],"scheduled_id":0,"sub_type":"","type":"","updated":""},"PaymentBatch":{}},"recurrence_size":0,"recurrence_unit":"","status":"","time_end":"","time_start":""},"status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "entries": [\n    {\n      "alias": {\n        "avatar": {\n          "anchor_uuid": "",\n          "image": [\n            {\n              "attachment_public_uuid": "",\n              "content_type": "",\n              "height": 0,\n              "width": 0\n            }\n          ],\n          "style": "",\n          "uuid": ""\n        },\n        "bunq_me": {\n          "name": "",\n          "service": "",\n          "type": "",\n          "value": ""\n        },\n        "country": "",\n        "display_name": "",\n        "iban": "",\n        "is_light": false,\n        "label_user": {\n          "avatar": {},\n          "country": "",\n          "display_name": "",\n          "public_nick_name": "",\n          "uuid": ""\n        },\n        "merchant_category_code": "",\n        "swift_account_number": "",\n        "swift_bic": "",\n        "transferwise_account_number": "",\n        "transferwise_bank_code": ""\n      },\n      "amount": {\n        "currency": "",\n        "value": ""\n      },\n      "attachment": [\n        {\n          "id": 0,\n          "monetary_account_id": 0\n        }\n      ],\n      "counterparty_alias": {},\n      "description": "",\n      "id": 0,\n      "merchant_reference": "",\n      "type": ""\n    }\n  ],\n  "number_of_required_accepts": 0,\n  "previous_updated_timestamp": "",\n  "schedule": {\n    "object": {\n      "Payment": {\n        "address_billing": {\n          "city": "",\n          "country": "",\n          "extra": "",\n          "house_number": "",\n          "is_user_address_updated": false,\n          "mailbox_name": "",\n          "po_box": "",\n          "postal_code": "",\n          "province": "",\n          "street": ""\n        },\n        "address_shipping": {},\n        "alias": {},\n        "allow_bunqto": false,\n        "amount": {},\n        "attachment": [\n          {}\n        ],\n        "balance_after_mutation": {},\n        "batch_id": 0,\n        "bunqto_expiry": "",\n        "bunqto_share_url": "",\n        "bunqto_status": "",\n        "bunqto_sub_status": "",\n        "bunqto_time_responded": "",\n        "counterparty_alias": {},\n        "created": "",\n        "description": "",\n        "geolocation": {\n          "altitude": 0,\n          "latitude": 0,\n          "longitude": 0,\n          "radius": 0\n        },\n        "id": 0,\n        "merchant_reference": "",\n        "monetary_account_id": 0,\n        "payment_auto_allocate_instance": {\n          "created": "",\n          "error_message": [],\n          "id": 0,\n          "payment_auto_allocate_id": 0,\n          "payment_batch": {\n            "payments": {\n              "Payment": []\n            }\n          },\n          "payment_id": 0,\n          "status": "",\n          "updated": ""\n        },\n        "request_reference_split_the_bill": [\n          {\n            "id": 0,\n            "type": ""\n          }\n        ],\n        "scheduled_id": 0,\n        "sub_type": "",\n        "type": "",\n        "updated": ""\n      },\n      "PaymentBatch": {}\n    },\n    "recurrence_size": 0,\n    "recurrence_unit": "",\n    "status": "",\n    "time_end": "",\n    "time_start": ""\n  },\n  "status": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"entries\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"number_of_required_accepts\": 0,\n  \"previous_updated_timestamp\": \"\",\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  entries: [
    {
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
          style: '',
          uuid: ''
        },
        bunq_me: {name: '', service: '', type: '', value: ''},
        country: '',
        display_name: '',
        iban: '',
        is_light: false,
        label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
        merchant_category_code: '',
        swift_account_number: '',
        swift_bic: '',
        transferwise_account_number: '',
        transferwise_bank_code: ''
      },
      amount: {currency: '', value: ''},
      attachment: [{id: 0, monetary_account_id: 0}],
      counterparty_alias: {},
      description: '',
      id: 0,
      merchant_reference: '',
      type: ''
    }
  ],
  number_of_required_accepts: 0,
  previous_updated_timestamp: '',
  schedule: {
    object: {
      Payment: {
        address_billing: {
          city: '',
          country: '',
          extra: '',
          house_number: '',
          is_user_address_updated: false,
          mailbox_name: '',
          po_box: '',
          postal_code: '',
          province: '',
          street: ''
        },
        address_shipping: {},
        alias: {},
        allow_bunqto: false,
        amount: {},
        attachment: [{}],
        balance_after_mutation: {},
        batch_id: 0,
        bunqto_expiry: '',
        bunqto_share_url: '',
        bunqto_status: '',
        bunqto_sub_status: '',
        bunqto_time_responded: '',
        counterparty_alias: {},
        created: '',
        description: '',
        geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
        id: 0,
        merchant_reference: '',
        monetary_account_id: 0,
        payment_auto_allocate_instance: {
          created: '',
          error_message: [],
          id: 0,
          payment_auto_allocate_id: 0,
          payment_batch: {payments: {Payment: []}},
          payment_id: 0,
          status: '',
          updated: ''
        },
        request_reference_split_the_bill: [{id: 0, type: ''}],
        scheduled_id: 0,
        sub_type: '',
        type: '',
        updated: ''
      },
      PaymentBatch: {}
    },
    recurrence_size: 0,
    recurrence_unit: '',
    status: '',
    time_end: '',
    time_start: ''
  },
  status: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    entries: [
      {
        alias: {
          avatar: {
            anchor_uuid: '',
            image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
            style: '',
            uuid: ''
          },
          bunq_me: {name: '', service: '', type: '', value: ''},
          country: '',
          display_name: '',
          iban: '',
          is_light: false,
          label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
          merchant_category_code: '',
          swift_account_number: '',
          swift_bic: '',
          transferwise_account_number: '',
          transferwise_bank_code: ''
        },
        amount: {currency: '', value: ''},
        attachment: [{id: 0, monetary_account_id: 0}],
        counterparty_alias: {},
        description: '',
        id: 0,
        merchant_reference: '',
        type: ''
      }
    ],
    number_of_required_accepts: 0,
    previous_updated_timestamp: '',
    schedule: {
      object: {
        Payment: {
          address_billing: {
            city: '',
            country: '',
            extra: '',
            house_number: '',
            is_user_address_updated: false,
            mailbox_name: '',
            po_box: '',
            postal_code: '',
            province: '',
            street: ''
          },
          address_shipping: {},
          alias: {},
          allow_bunqto: false,
          amount: {},
          attachment: [{}],
          balance_after_mutation: {},
          batch_id: 0,
          bunqto_expiry: '',
          bunqto_share_url: '',
          bunqto_status: '',
          bunqto_sub_status: '',
          bunqto_time_responded: '',
          counterparty_alias: {},
          created: '',
          description: '',
          geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
          id: 0,
          merchant_reference: '',
          monetary_account_id: 0,
          payment_auto_allocate_instance: {
            created: '',
            error_message: [],
            id: 0,
            payment_auto_allocate_id: 0,
            payment_batch: {payments: {Payment: []}},
            payment_id: 0,
            status: '',
            updated: ''
          },
          request_reference_split_the_bill: [{id: 0, type: ''}],
          scheduled_id: 0,
          sub_type: '',
          type: '',
          updated: ''
        },
        PaymentBatch: {}
      },
      recurrence_size: 0,
      recurrence_unit: '',
      status: '',
      time_end: '',
      time_start: ''
    },
    status: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  entries: [
    {
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [
            {
              attachment_public_uuid: '',
              content_type: '',
              height: 0,
              width: 0
            }
          ],
          style: '',
          uuid: ''
        },
        bunq_me: {
          name: '',
          service: '',
          type: '',
          value: ''
        },
        country: '',
        display_name: '',
        iban: '',
        is_light: false,
        label_user: {
          avatar: {},
          country: '',
          display_name: '',
          public_nick_name: '',
          uuid: ''
        },
        merchant_category_code: '',
        swift_account_number: '',
        swift_bic: '',
        transferwise_account_number: '',
        transferwise_bank_code: ''
      },
      amount: {
        currency: '',
        value: ''
      },
      attachment: [
        {
          id: 0,
          monetary_account_id: 0
        }
      ],
      counterparty_alias: {},
      description: '',
      id: 0,
      merchant_reference: '',
      type: ''
    }
  ],
  number_of_required_accepts: 0,
  previous_updated_timestamp: '',
  schedule: {
    object: {
      Payment: {
        address_billing: {
          city: '',
          country: '',
          extra: '',
          house_number: '',
          is_user_address_updated: false,
          mailbox_name: '',
          po_box: '',
          postal_code: '',
          province: '',
          street: ''
        },
        address_shipping: {},
        alias: {},
        allow_bunqto: false,
        amount: {},
        attachment: [
          {}
        ],
        balance_after_mutation: {},
        batch_id: 0,
        bunqto_expiry: '',
        bunqto_share_url: '',
        bunqto_status: '',
        bunqto_sub_status: '',
        bunqto_time_responded: '',
        counterparty_alias: {},
        created: '',
        description: '',
        geolocation: {
          altitude: 0,
          latitude: 0,
          longitude: 0,
          radius: 0
        },
        id: 0,
        merchant_reference: '',
        monetary_account_id: 0,
        payment_auto_allocate_instance: {
          created: '',
          error_message: [],
          id: 0,
          payment_auto_allocate_id: 0,
          payment_batch: {
            payments: {
              Payment: []
            }
          },
          payment_id: 0,
          status: '',
          updated: ''
        },
        request_reference_split_the_bill: [
          {
            id: 0,
            type: ''
          }
        ],
        scheduled_id: 0,
        sub_type: '',
        type: '',
        updated: ''
      },
      PaymentBatch: {}
    },
    recurrence_size: 0,
    recurrence_unit: '',
    status: '',
    time_end: '',
    time_start: ''
  },
  status: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    entries: [
      {
        alias: {
          avatar: {
            anchor_uuid: '',
            image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
            style: '',
            uuid: ''
          },
          bunq_me: {name: '', service: '', type: '', value: ''},
          country: '',
          display_name: '',
          iban: '',
          is_light: false,
          label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
          merchant_category_code: '',
          swift_account_number: '',
          swift_bic: '',
          transferwise_account_number: '',
          transferwise_bank_code: ''
        },
        amount: {currency: '', value: ''},
        attachment: [{id: 0, monetary_account_id: 0}],
        counterparty_alias: {},
        description: '',
        id: 0,
        merchant_reference: '',
        type: ''
      }
    ],
    number_of_required_accepts: 0,
    previous_updated_timestamp: '',
    schedule: {
      object: {
        Payment: {
          address_billing: {
            city: '',
            country: '',
            extra: '',
            house_number: '',
            is_user_address_updated: false,
            mailbox_name: '',
            po_box: '',
            postal_code: '',
            province: '',
            street: ''
          },
          address_shipping: {},
          alias: {},
          allow_bunqto: false,
          amount: {},
          attachment: [{}],
          balance_after_mutation: {},
          batch_id: 0,
          bunqto_expiry: '',
          bunqto_share_url: '',
          bunqto_status: '',
          bunqto_sub_status: '',
          bunqto_time_responded: '',
          counterparty_alias: {},
          created: '',
          description: '',
          geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
          id: 0,
          merchant_reference: '',
          monetary_account_id: 0,
          payment_auto_allocate_instance: {
            created: '',
            error_message: [],
            id: 0,
            payment_auto_allocate_id: 0,
            payment_batch: {payments: {Payment: []}},
            payment_id: 0,
            status: '',
            updated: ''
          },
          request_reference_split_the_bill: [{id: 0, type: ''}],
          scheduled_id: 0,
          sub_type: '',
          type: '',
          updated: ''
        },
        PaymentBatch: {}
      },
      recurrence_size: 0,
      recurrence_unit: '',
      status: '',
      time_end: '',
      time_start: ''
    },
    status: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"entries":[{"alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"amount":{"currency":"","value":""},"attachment":[{"id":0,"monetary_account_id":0}],"counterparty_alias":{},"description":"","id":0,"merchant_reference":"","type":""}],"number_of_required_accepts":0,"previous_updated_timestamp":"","schedule":{"object":{"Payment":{"address_billing":{"city":"","country":"","extra":"","house_number":"","is_user_address_updated":false,"mailbox_name":"","po_box":"","postal_code":"","province":"","street":""},"address_shipping":{},"alias":{},"allow_bunqto":false,"amount":{},"attachment":[{}],"balance_after_mutation":{},"batch_id":0,"bunqto_expiry":"","bunqto_share_url":"","bunqto_status":"","bunqto_sub_status":"","bunqto_time_responded":"","counterparty_alias":{},"created":"","description":"","geolocation":{"altitude":0,"latitude":0,"longitude":0,"radius":0},"id":0,"merchant_reference":"","monetary_account_id":0,"payment_auto_allocate_instance":{"created":"","error_message":[],"id":0,"payment_auto_allocate_id":0,"payment_batch":{"payments":{"Payment":[]}},"payment_id":0,"status":"","updated":""},"request_reference_split_the_bill":[{"id":0,"type":""}],"scheduled_id":0,"sub_type":"","type":"","updated":""},"PaymentBatch":{}},"recurrence_size":0,"recurrence_unit":"","status":"","time_end":"","time_start":""},"status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"entries": @[ @{ @"alias": @{ @"avatar": @{ @"anchor_uuid": @"", @"image": @[ @{ @"attachment_public_uuid": @"", @"content_type": @"", @"height": @0, @"width": @0 } ], @"style": @"", @"uuid": @"" }, @"bunq_me": @{ @"name": @"", @"service": @"", @"type": @"", @"value": @"" }, @"country": @"", @"display_name": @"", @"iban": @"", @"is_light": @NO, @"label_user": @{ @"avatar": @{  }, @"country": @"", @"display_name": @"", @"public_nick_name": @"", @"uuid": @"" }, @"merchant_category_code": @"", @"swift_account_number": @"", @"swift_bic": @"", @"transferwise_account_number": @"", @"transferwise_bank_code": @"" }, @"amount": @{ @"currency": @"", @"value": @"" }, @"attachment": @[ @{ @"id": @0, @"monetary_account_id": @0 } ], @"counterparty_alias": @{  }, @"description": @"", @"id": @0, @"merchant_reference": @"", @"type": @"" } ],
                              @"number_of_required_accepts": @0,
                              @"previous_updated_timestamp": @"",
                              @"schedule": @{ @"object": @{ @"Payment": @{ @"address_billing": @{ @"city": @"", @"country": @"", @"extra": @"", @"house_number": @"", @"is_user_address_updated": @NO, @"mailbox_name": @"", @"po_box": @"", @"postal_code": @"", @"province": @"", @"street": @"" }, @"address_shipping": @{  }, @"alias": @{  }, @"allow_bunqto": @NO, @"amount": @{  }, @"attachment": @[ @{  } ], @"balance_after_mutation": @{  }, @"batch_id": @0, @"bunqto_expiry": @"", @"bunqto_share_url": @"", @"bunqto_status": @"", @"bunqto_sub_status": @"", @"bunqto_time_responded": @"", @"counterparty_alias": @{  }, @"created": @"", @"description": @"", @"geolocation": @{ @"altitude": @0, @"latitude": @0, @"longitude": @0, @"radius": @0 }, @"id": @0, @"merchant_reference": @"", @"monetary_account_id": @0, @"payment_auto_allocate_instance": @{ @"created": @"", @"error_message": @[  ], @"id": @0, @"payment_auto_allocate_id": @0, @"payment_batch": @{ @"payments": @{ @"Payment": @[  ] } }, @"payment_id": @0, @"status": @"", @"updated": @"" }, @"request_reference_split_the_bill": @[ @{ @"id": @0, @"type": @"" } ], @"scheduled_id": @0, @"sub_type": @"", @"type": @"", @"updated": @"" }, @"PaymentBatch": @{  } }, @"recurrence_size": @0, @"recurrence_unit": @"", @"status": @"", @"time_end": @"", @"time_start": @"" },
                              @"status": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"entries\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"number_of_required_accepts\": 0,\n  \"previous_updated_timestamp\": \"\",\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'entries' => [
        [
                'alias' => [
                                'avatar' => [
                                                                'anchor_uuid' => '',
                                                                'image' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'attachment_public_uuid' => '',
                                                                                                                                                                                                                                                                'content_type' => '',
                                                                                                                                                                                                                                                                'height' => 0,
                                                                                                                                                                                                                                                                'width' => 0
                                                                                                                                ]
                                                                ],
                                                                'style' => '',
                                                                'uuid' => ''
                                ],
                                'bunq_me' => [
                                                                'name' => '',
                                                                'service' => '',
                                                                'type' => '',
                                                                'value' => ''
                                ],
                                'country' => '',
                                'display_name' => '',
                                'iban' => '',
                                'is_light' => null,
                                'label_user' => [
                                                                'avatar' => [
                                                                                                                                
                                                                ],
                                                                'country' => '',
                                                                'display_name' => '',
                                                                'public_nick_name' => '',
                                                                'uuid' => ''
                                ],
                                'merchant_category_code' => '',
                                'swift_account_number' => '',
                                'swift_bic' => '',
                                'transferwise_account_number' => '',
                                'transferwise_bank_code' => ''
                ],
                'amount' => [
                                'currency' => '',
                                'value' => ''
                ],
                'attachment' => [
                                [
                                                                'id' => 0,
                                                                'monetary_account_id' => 0
                                ]
                ],
                'counterparty_alias' => [
                                
                ],
                'description' => '',
                'id' => 0,
                'merchant_reference' => '',
                'type' => ''
        ]
    ],
    'number_of_required_accepts' => 0,
    'previous_updated_timestamp' => '',
    'schedule' => [
        'object' => [
                'Payment' => [
                                'address_billing' => [
                                                                'city' => '',
                                                                'country' => '',
                                                                'extra' => '',
                                                                'house_number' => '',
                                                                'is_user_address_updated' => null,
                                                                'mailbox_name' => '',
                                                                'po_box' => '',
                                                                'postal_code' => '',
                                                                'province' => '',
                                                                'street' => ''
                                ],
                                'address_shipping' => [
                                                                
                                ],
                                'alias' => [
                                                                
                                ],
                                'allow_bunqto' => null,
                                'amount' => [
                                                                
                                ],
                                'attachment' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'balance_after_mutation' => [
                                                                
                                ],
                                'batch_id' => 0,
                                'bunqto_expiry' => '',
                                'bunqto_share_url' => '',
                                'bunqto_status' => '',
                                'bunqto_sub_status' => '',
                                'bunqto_time_responded' => '',
                                'counterparty_alias' => [
                                                                
                                ],
                                'created' => '',
                                'description' => '',
                                'geolocation' => [
                                                                'altitude' => 0,
                                                                'latitude' => 0,
                                                                'longitude' => 0,
                                                                'radius' => 0
                                ],
                                'id' => 0,
                                'merchant_reference' => '',
                                'monetary_account_id' => 0,
                                'payment_auto_allocate_instance' => [
                                                                'created' => '',
                                                                'error_message' => [
                                                                                                                                
                                                                ],
                                                                'id' => 0,
                                                                'payment_auto_allocate_id' => 0,
                                                                'payment_batch' => [
                                                                                                                                'payments' => [
                                                                                                                                                                                                                                                                'Payment' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ]
                                                                                                                                ]
                                                                ],
                                                                'payment_id' => 0,
                                                                'status' => '',
                                                                'updated' => ''
                                ],
                                'request_reference_split_the_bill' => [
                                                                [
                                                                                                                                'id' => 0,
                                                                                                                                'type' => ''
                                                                ]
                                ],
                                'scheduled_id' => 0,
                                'sub_type' => '',
                                'type' => '',
                                'updated' => ''
                ],
                'PaymentBatch' => [
                                
                ]
        ],
        'recurrence_size' => 0,
        'recurrence_unit' => '',
        'status' => '',
        'time_end' => '',
        'time_start' => ''
    ],
    'status' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId', [
  'body' => '{
  "entries": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "counterparty_alias": {},
      "description": "",
      "id": 0,
      "merchant_reference": "",
      "type": ""
    }
  ],
  "number_of_required_accepts": 0,
  "previous_updated_timestamp": "",
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  },
  "status": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'entries' => [
    [
        'alias' => [
                'avatar' => [
                                'anchor_uuid' => '',
                                'image' => [
                                                                [
                                                                                                                                'attachment_public_uuid' => '',
                                                                                                                                'content_type' => '',
                                                                                                                                'height' => 0,
                                                                                                                                'width' => 0
                                                                ]
                                ],
                                'style' => '',
                                'uuid' => ''
                ],
                'bunq_me' => [
                                'name' => '',
                                'service' => '',
                                'type' => '',
                                'value' => ''
                ],
                'country' => '',
                'display_name' => '',
                'iban' => '',
                'is_light' => null,
                'label_user' => [
                                'avatar' => [
                                                                
                                ],
                                'country' => '',
                                'display_name' => '',
                                'public_nick_name' => '',
                                'uuid' => ''
                ],
                'merchant_category_code' => '',
                'swift_account_number' => '',
                'swift_bic' => '',
                'transferwise_account_number' => '',
                'transferwise_bank_code' => ''
        ],
        'amount' => [
                'currency' => '',
                'value' => ''
        ],
        'attachment' => [
                [
                                'id' => 0,
                                'monetary_account_id' => 0
                ]
        ],
        'counterparty_alias' => [
                
        ],
        'description' => '',
        'id' => 0,
        'merchant_reference' => '',
        'type' => ''
    ]
  ],
  'number_of_required_accepts' => 0,
  'previous_updated_timestamp' => '',
  'schedule' => [
    'object' => [
        'Payment' => [
                'address_billing' => [
                                'city' => '',
                                'country' => '',
                                'extra' => '',
                                'house_number' => '',
                                'is_user_address_updated' => null,
                                'mailbox_name' => '',
                                'po_box' => '',
                                'postal_code' => '',
                                'province' => '',
                                'street' => ''
                ],
                'address_shipping' => [
                                
                ],
                'alias' => [
                                
                ],
                'allow_bunqto' => null,
                'amount' => [
                                
                ],
                'attachment' => [
                                [
                                                                
                                ]
                ],
                'balance_after_mutation' => [
                                
                ],
                'batch_id' => 0,
                'bunqto_expiry' => '',
                'bunqto_share_url' => '',
                'bunqto_status' => '',
                'bunqto_sub_status' => '',
                'bunqto_time_responded' => '',
                'counterparty_alias' => [
                                
                ],
                'created' => '',
                'description' => '',
                'geolocation' => [
                                'altitude' => 0,
                                'latitude' => 0,
                                'longitude' => 0,
                                'radius' => 0
                ],
                'id' => 0,
                'merchant_reference' => '',
                'monetary_account_id' => 0,
                'payment_auto_allocate_instance' => [
                                'created' => '',
                                'error_message' => [
                                                                
                                ],
                                'id' => 0,
                                'payment_auto_allocate_id' => 0,
                                'payment_batch' => [
                                                                'payments' => [
                                                                                                                                'Payment' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'payment_id' => 0,
                                'status' => '',
                                'updated' => ''
                ],
                'request_reference_split_the_bill' => [
                                [
                                                                'id' => 0,
                                                                'type' => ''
                                ]
                ],
                'scheduled_id' => 0,
                'sub_type' => '',
                'type' => '',
                'updated' => ''
        ],
        'PaymentBatch' => [
                
        ]
    ],
    'recurrence_size' => 0,
    'recurrence_unit' => '',
    'status' => '',
    'time_end' => '',
    'time_start' => ''
  ],
  'status' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'entries' => [
    [
        'alias' => [
                'avatar' => [
                                'anchor_uuid' => '',
                                'image' => [
                                                                [
                                                                                                                                'attachment_public_uuid' => '',
                                                                                                                                'content_type' => '',
                                                                                                                                'height' => 0,
                                                                                                                                'width' => 0
                                                                ]
                                ],
                                'style' => '',
                                'uuid' => ''
                ],
                'bunq_me' => [
                                'name' => '',
                                'service' => '',
                                'type' => '',
                                'value' => ''
                ],
                'country' => '',
                'display_name' => '',
                'iban' => '',
                'is_light' => null,
                'label_user' => [
                                'avatar' => [
                                                                
                                ],
                                'country' => '',
                                'display_name' => '',
                                'public_nick_name' => '',
                                'uuid' => ''
                ],
                'merchant_category_code' => '',
                'swift_account_number' => '',
                'swift_bic' => '',
                'transferwise_account_number' => '',
                'transferwise_bank_code' => ''
        ],
        'amount' => [
                'currency' => '',
                'value' => ''
        ],
        'attachment' => [
                [
                                'id' => 0,
                                'monetary_account_id' => 0
                ]
        ],
        'counterparty_alias' => [
                
        ],
        'description' => '',
        'id' => 0,
        'merchant_reference' => '',
        'type' => ''
    ]
  ],
  'number_of_required_accepts' => 0,
  'previous_updated_timestamp' => '',
  'schedule' => [
    'object' => [
        'Payment' => [
                'address_billing' => [
                                'city' => '',
                                'country' => '',
                                'extra' => '',
                                'house_number' => '',
                                'is_user_address_updated' => null,
                                'mailbox_name' => '',
                                'po_box' => '',
                                'postal_code' => '',
                                'province' => '',
                                'street' => ''
                ],
                'address_shipping' => [
                                
                ],
                'alias' => [
                                
                ],
                'allow_bunqto' => null,
                'amount' => [
                                
                ],
                'attachment' => [
                                [
                                                                
                                ]
                ],
                'balance_after_mutation' => [
                                
                ],
                'batch_id' => 0,
                'bunqto_expiry' => '',
                'bunqto_share_url' => '',
                'bunqto_status' => '',
                'bunqto_sub_status' => '',
                'bunqto_time_responded' => '',
                'counterparty_alias' => [
                                
                ],
                'created' => '',
                'description' => '',
                'geolocation' => [
                                'altitude' => 0,
                                'latitude' => 0,
                                'longitude' => 0,
                                'radius' => 0
                ],
                'id' => 0,
                'merchant_reference' => '',
                'monetary_account_id' => 0,
                'payment_auto_allocate_instance' => [
                                'created' => '',
                                'error_message' => [
                                                                
                                ],
                                'id' => 0,
                                'payment_auto_allocate_id' => 0,
                                'payment_batch' => [
                                                                'payments' => [
                                                                                                                                'Payment' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'payment_id' => 0,
                                'status' => '',
                                'updated' => ''
                ],
                'request_reference_split_the_bill' => [
                                [
                                                                'id' => 0,
                                                                'type' => ''
                                ]
                ],
                'scheduled_id' => 0,
                'sub_type' => '',
                'type' => '',
                'updated' => ''
        ],
        'PaymentBatch' => [
                
        ]
    ],
    'recurrence_size' => 0,
    'recurrence_unit' => '',
    'status' => '',
    'time_end' => '',
    'time_start' => ''
  ],
  'status' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "entries": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "counterparty_alias": {},
      "description": "",
      "id": 0,
      "merchant_reference": "",
      "type": ""
    }
  ],
  "number_of_required_accepts": 0,
  "previous_updated_timestamp": "",
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  },
  "status": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "entries": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "counterparty_alias": {},
      "description": "",
      "id": 0,
      "merchant_reference": "",
      "type": ""
    }
  ],
  "number_of_required_accepts": 0,
  "previous_updated_timestamp": "",
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  },
  "status": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"entries\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"number_of_required_accepts\": 0,\n  \"previous_updated_timestamp\": \"\",\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId"

payload = {
    "entries": [
        {
            "alias": {
                "avatar": {
                    "anchor_uuid": "",
                    "image": [
                        {
                            "attachment_public_uuid": "",
                            "content_type": "",
                            "height": 0,
                            "width": 0
                        }
                    ],
                    "style": "",
                    "uuid": ""
                },
                "bunq_me": {
                    "name": "",
                    "service": "",
                    "type": "",
                    "value": ""
                },
                "country": "",
                "display_name": "",
                "iban": "",
                "is_light": False,
                "label_user": {
                    "avatar": {},
                    "country": "",
                    "display_name": "",
                    "public_nick_name": "",
                    "uuid": ""
                },
                "merchant_category_code": "",
                "swift_account_number": "",
                "swift_bic": "",
                "transferwise_account_number": "",
                "transferwise_bank_code": ""
            },
            "amount": {
                "currency": "",
                "value": ""
            },
            "attachment": [
                {
                    "id": 0,
                    "monetary_account_id": 0
                }
            ],
            "counterparty_alias": {},
            "description": "",
            "id": 0,
            "merchant_reference": "",
            "type": ""
        }
    ],
    "number_of_required_accepts": 0,
    "previous_updated_timestamp": "",
    "schedule": {
        "object": {
            "Payment": {
                "address_billing": {
                    "city": "",
                    "country": "",
                    "extra": "",
                    "house_number": "",
                    "is_user_address_updated": False,
                    "mailbox_name": "",
                    "po_box": "",
                    "postal_code": "",
                    "province": "",
                    "street": ""
                },
                "address_shipping": {},
                "alias": {},
                "allow_bunqto": False,
                "amount": {},
                "attachment": [{}],
                "balance_after_mutation": {},
                "batch_id": 0,
                "bunqto_expiry": "",
                "bunqto_share_url": "",
                "bunqto_status": "",
                "bunqto_sub_status": "",
                "bunqto_time_responded": "",
                "counterparty_alias": {},
                "created": "",
                "description": "",
                "geolocation": {
                    "altitude": 0,
                    "latitude": 0,
                    "longitude": 0,
                    "radius": 0
                },
                "id": 0,
                "merchant_reference": "",
                "monetary_account_id": 0,
                "payment_auto_allocate_instance": {
                    "created": "",
                    "error_message": [],
                    "id": 0,
                    "payment_auto_allocate_id": 0,
                    "payment_batch": { "payments": { "Payment": [] } },
                    "payment_id": 0,
                    "status": "",
                    "updated": ""
                },
                "request_reference_split_the_bill": [
                    {
                        "id": 0,
                        "type": ""
                    }
                ],
                "scheduled_id": 0,
                "sub_type": "",
                "type": "",
                "updated": ""
            },
            "PaymentBatch": {}
        },
        "recurrence_size": 0,
        "recurrence_unit": "",
        "status": "",
        "time_end": "",
        "time_start": ""
    },
    "status": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId"

payload <- "{\n  \"entries\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"number_of_required_accepts\": 0,\n  \"previous_updated_timestamp\": \"\",\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"entries\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"number_of_required_accepts\": 0,\n  \"previous_updated_timestamp\": \"\",\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"entries\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"number_of_required_accepts\": 0,\n  \"previous_updated_timestamp\": \"\",\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId";

    let payload = json!({
        "entries": (
            json!({
                "alias": json!({
                    "avatar": json!({
                        "anchor_uuid": "",
                        "image": (
                            json!({
                                "attachment_public_uuid": "",
                                "content_type": "",
                                "height": 0,
                                "width": 0
                            })
                        ),
                        "style": "",
                        "uuid": ""
                    }),
                    "bunq_me": json!({
                        "name": "",
                        "service": "",
                        "type": "",
                        "value": ""
                    }),
                    "country": "",
                    "display_name": "",
                    "iban": "",
                    "is_light": false,
                    "label_user": json!({
                        "avatar": json!({}),
                        "country": "",
                        "display_name": "",
                        "public_nick_name": "",
                        "uuid": ""
                    }),
                    "merchant_category_code": "",
                    "swift_account_number": "",
                    "swift_bic": "",
                    "transferwise_account_number": "",
                    "transferwise_bank_code": ""
                }),
                "amount": json!({
                    "currency": "",
                    "value": ""
                }),
                "attachment": (
                    json!({
                        "id": 0,
                        "monetary_account_id": 0
                    })
                ),
                "counterparty_alias": json!({}),
                "description": "",
                "id": 0,
                "merchant_reference": "",
                "type": ""
            })
        ),
        "number_of_required_accepts": 0,
        "previous_updated_timestamp": "",
        "schedule": json!({
            "object": json!({
                "Payment": json!({
                    "address_billing": json!({
                        "city": "",
                        "country": "",
                        "extra": "",
                        "house_number": "",
                        "is_user_address_updated": false,
                        "mailbox_name": "",
                        "po_box": "",
                        "postal_code": "",
                        "province": "",
                        "street": ""
                    }),
                    "address_shipping": json!({}),
                    "alias": json!({}),
                    "allow_bunqto": false,
                    "amount": json!({}),
                    "attachment": (json!({})),
                    "balance_after_mutation": json!({}),
                    "batch_id": 0,
                    "bunqto_expiry": "",
                    "bunqto_share_url": "",
                    "bunqto_status": "",
                    "bunqto_sub_status": "",
                    "bunqto_time_responded": "",
                    "counterparty_alias": json!({}),
                    "created": "",
                    "description": "",
                    "geolocation": json!({
                        "altitude": 0,
                        "latitude": 0,
                        "longitude": 0,
                        "radius": 0
                    }),
                    "id": 0,
                    "merchant_reference": "",
                    "monetary_account_id": 0,
                    "payment_auto_allocate_instance": json!({
                        "created": "",
                        "error_message": (),
                        "id": 0,
                        "payment_auto_allocate_id": 0,
                        "payment_batch": json!({"payments": json!({"Payment": ()})}),
                        "payment_id": 0,
                        "status": "",
                        "updated": ""
                    }),
                    "request_reference_split_the_bill": (
                        json!({
                            "id": 0,
                            "type": ""
                        })
                    ),
                    "scheduled_id": 0,
                    "sub_type": "",
                    "type": "",
                    "updated": ""
                }),
                "PaymentBatch": json!({})
            }),
            "recurrence_size": 0,
            "recurrence_unit": "",
            "status": "",
            "time_end": "",
            "time_start": ""
        }),
        "status": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "entries": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "counterparty_alias": {},
      "description": "",
      "id": 0,
      "merchant_reference": "",
      "type": ""
    }
  ],
  "number_of_required_accepts": 0,
  "previous_updated_timestamp": "",
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  },
  "status": ""
}'
echo '{
  "entries": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "counterparty_alias": {},
      "description": "",
      "id": 0,
      "merchant_reference": "",
      "type": ""
    }
  ],
  "number_of_required_accepts": 0,
  "previous_updated_timestamp": "",
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  },
  "status": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "entries": [\n    {\n      "alias": {\n        "avatar": {\n          "anchor_uuid": "",\n          "image": [\n            {\n              "attachment_public_uuid": "",\n              "content_type": "",\n              "height": 0,\n              "width": 0\n            }\n          ],\n          "style": "",\n          "uuid": ""\n        },\n        "bunq_me": {\n          "name": "",\n          "service": "",\n          "type": "",\n          "value": ""\n        },\n        "country": "",\n        "display_name": "",\n        "iban": "",\n        "is_light": false,\n        "label_user": {\n          "avatar": {},\n          "country": "",\n          "display_name": "",\n          "public_nick_name": "",\n          "uuid": ""\n        },\n        "merchant_category_code": "",\n        "swift_account_number": "",\n        "swift_bic": "",\n        "transferwise_account_number": "",\n        "transferwise_bank_code": ""\n      },\n      "amount": {\n        "currency": "",\n        "value": ""\n      },\n      "attachment": [\n        {\n          "id": 0,\n          "monetary_account_id": 0\n        }\n      ],\n      "counterparty_alias": {},\n      "description": "",\n      "id": 0,\n      "merchant_reference": "",\n      "type": ""\n    }\n  ],\n  "number_of_required_accepts": 0,\n  "previous_updated_timestamp": "",\n  "schedule": {\n    "object": {\n      "Payment": {\n        "address_billing": {\n          "city": "",\n          "country": "",\n          "extra": "",\n          "house_number": "",\n          "is_user_address_updated": false,\n          "mailbox_name": "",\n          "po_box": "",\n          "postal_code": "",\n          "province": "",\n          "street": ""\n        },\n        "address_shipping": {},\n        "alias": {},\n        "allow_bunqto": false,\n        "amount": {},\n        "attachment": [\n          {}\n        ],\n        "balance_after_mutation": {},\n        "batch_id": 0,\n        "bunqto_expiry": "",\n        "bunqto_share_url": "",\n        "bunqto_status": "",\n        "bunqto_sub_status": "",\n        "bunqto_time_responded": "",\n        "counterparty_alias": {},\n        "created": "",\n        "description": "",\n        "geolocation": {\n          "altitude": 0,\n          "latitude": 0,\n          "longitude": 0,\n          "radius": 0\n        },\n        "id": 0,\n        "merchant_reference": "",\n        "monetary_account_id": 0,\n        "payment_auto_allocate_instance": {\n          "created": "",\n          "error_message": [],\n          "id": 0,\n          "payment_auto_allocate_id": 0,\n          "payment_batch": {\n            "payments": {\n              "Payment": []\n            }\n          },\n          "payment_id": 0,\n          "status": "",\n          "updated": ""\n        },\n        "request_reference_split_the_bill": [\n          {\n            "id": 0,\n            "type": ""\n          }\n        ],\n        "scheduled_id": 0,\n        "sub_type": "",\n        "type": "",\n        "updated": ""\n      },\n      "PaymentBatch": {}\n    },\n    "recurrence_size": 0,\n    "recurrence_unit": "",\n    "status": "",\n    "time_end": "",\n    "time_start": ""\n  },\n  "status": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "entries": [
    [
      "alias": [
        "avatar": [
          "anchor_uuid": "",
          "image": [
            [
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            ]
          ],
          "style": "",
          "uuid": ""
        ],
        "bunq_me": [
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        ],
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": [
          "avatar": [],
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        ],
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      ],
      "amount": [
        "currency": "",
        "value": ""
      ],
      "attachment": [
        [
          "id": 0,
          "monetary_account_id": 0
        ]
      ],
      "counterparty_alias": [],
      "description": "",
      "id": 0,
      "merchant_reference": "",
      "type": ""
    ]
  ],
  "number_of_required_accepts": 0,
  "previous_updated_timestamp": "",
  "schedule": [
    "object": [
      "Payment": [
        "address_billing": [
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        ],
        "address_shipping": [],
        "alias": [],
        "allow_bunqto": false,
        "amount": [],
        "attachment": [[]],
        "balance_after_mutation": [],
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": [],
        "created": "",
        "description": "",
        "geolocation": [
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        ],
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": [
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": ["payments": ["Payment": []]],
          "payment_id": 0,
          "status": "",
          "updated": ""
        ],
        "request_reference_split_the_bill": [
          [
            "id": 0,
            "type": ""
          ]
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      ],
      "PaymentBatch": []
    ],
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  ],
  "status": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_Event_for_User
{{baseUrl}}/user/:userID/event
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/event");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/event" {:headers {:user-agent ""
                                                                        :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/event"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/event"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/event");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/event"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/event HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/event")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/event"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/event")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/event")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/event');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/event',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/event';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/event',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/event")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/event',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/event',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/event');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/event',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/event';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/event"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/event" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/event",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/event', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/event');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/event');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/event' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/event' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/event", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/event"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/event"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/event")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/event') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/event";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/event \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/event \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/event
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/event")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_Event_for_User
{{baseUrl}}/user/:userID/event/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/event/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/event/:itemId" {:headers {:user-agent ""
                                                                                :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/event/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/event/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/event/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/event/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/event/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/event/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/event/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/event/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/event/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/event/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/event/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/event/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/event/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/event/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/event/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/event/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/event/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/event/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/event/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/event/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/event/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/event/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/event/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/event/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/event/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/event/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/event/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/event/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/event/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/event/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/event/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/event/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/event/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/event/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/event/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/event/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/event/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_ExportAnnualOverview_for_User
{{baseUrl}}/user/:userID/export-annual-overview
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
BODY json

{
  "year": 0
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/export-annual-overview");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"year\": 0\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/export-annual-overview" {:headers {:user-agent ""
                                                                                          :x-bunq-client-authentication ""}
                                                                                :content-type :json
                                                                                :form-params {:year 0}})
require "http/client"

url = "{{baseUrl}}/user/:userID/export-annual-overview"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"year\": 0\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/export-annual-overview"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"year\": 0\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/export-annual-overview");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"year\": 0\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/export-annual-overview"

	payload := strings.NewReader("{\n  \"year\": 0\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/export-annual-overview HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 15

{
  "year": 0
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/export-annual-overview")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"year\": 0\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/export-annual-overview"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"year\": 0\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"year\": 0\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/export-annual-overview")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/export-annual-overview")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"year\": 0\n}")
  .asString();
const data = JSON.stringify({
  year: 0
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/export-annual-overview');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/export-annual-overview',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {year: 0}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/export-annual-overview';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"year":0}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/export-annual-overview',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "year": 0\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"year\": 0\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/export-annual-overview")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/export-annual-overview',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({year: 0}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/export-annual-overview',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {year: 0},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/export-annual-overview');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  year: 0
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/export-annual-overview',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {year: 0}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/export-annual-overview';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"year":0}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"year": @0 };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/export-annual-overview"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/export-annual-overview" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"year\": 0\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/export-annual-overview",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'year' => 0
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/export-annual-overview', [
  'body' => '{
  "year": 0
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/export-annual-overview');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'year' => 0
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'year' => 0
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/export-annual-overview');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/export-annual-overview' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "year": 0
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/export-annual-overview' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "year": 0
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"year\": 0\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/export-annual-overview", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/export-annual-overview"

payload = { "year": 0 }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/export-annual-overview"

payload <- "{\n  \"year\": 0\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/export-annual-overview")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"year\": 0\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/export-annual-overview') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"year\": 0\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/export-annual-overview";

    let payload = json!({"year": 0});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/export-annual-overview \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "year": 0
}'
echo '{
  "year": 0
}' |  \
  http POST {{baseUrl}}/user/:userID/export-annual-overview \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "year": 0\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/export-annual-overview
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["year": 0] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/export-annual-overview")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_ExportAnnualOverview_for_User
{{baseUrl}}/user/:userID/export-annual-overview/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/export-annual-overview/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/export-annual-overview/:itemId" {:headers {:user-agent ""
                                                                                                    :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/export-annual-overview/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/export-annual-overview/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/export-annual-overview/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/export-annual-overview/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/export-annual-overview/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/export-annual-overview/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/export-annual-overview/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/export-annual-overview/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/export-annual-overview/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/export-annual-overview/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/export-annual-overview/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/export-annual-overview/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/export-annual-overview/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/export-annual-overview/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/export-annual-overview/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/export-annual-overview/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/export-annual-overview/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/export-annual-overview/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/export-annual-overview/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/export-annual-overview/:itemId"]
                                                       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}}/user/:userID/export-annual-overview/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/export-annual-overview/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/export-annual-overview/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/export-annual-overview/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/export-annual-overview/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/export-annual-overview/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/export-annual-overview/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/export-annual-overview/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/export-annual-overview/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/export-annual-overview/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/export-annual-overview/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/export-annual-overview/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/export-annual-overview/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/export-annual-overview/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/export-annual-overview/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/export-annual-overview/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/export-annual-overview/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_ExportAnnualOverview_for_User
{{baseUrl}}/user/:userID/export-annual-overview
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/export-annual-overview");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/export-annual-overview" {:headers {:user-agent ""
                                                                                         :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/export-annual-overview"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/export-annual-overview"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/export-annual-overview");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/export-annual-overview"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/export-annual-overview HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/export-annual-overview")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/export-annual-overview"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/export-annual-overview")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/export-annual-overview")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/export-annual-overview');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/export-annual-overview',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/export-annual-overview';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/export-annual-overview',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/export-annual-overview")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/export-annual-overview',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/export-annual-overview',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/export-annual-overview');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/export-annual-overview',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/export-annual-overview';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/export-annual-overview"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/export-annual-overview" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/export-annual-overview",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/export-annual-overview', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/export-annual-overview');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/export-annual-overview');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/export-annual-overview' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/export-annual-overview' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/export-annual-overview", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/export-annual-overview"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/export-annual-overview"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/export-annual-overview")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/export-annual-overview') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/export-annual-overview";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/export-annual-overview \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/export-annual-overview \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/export-annual-overview
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/export-annual-overview")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_ExportAnnualOverview_for_User
{{baseUrl}}/user/:userID/export-annual-overview/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/export-annual-overview/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/export-annual-overview/:itemId" {:headers {:user-agent ""
                                                                                                 :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/export-annual-overview/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/export-annual-overview/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/export-annual-overview/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/export-annual-overview/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/export-annual-overview/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/export-annual-overview/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/export-annual-overview/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/export-annual-overview/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/export-annual-overview/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/export-annual-overview/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/export-annual-overview/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/export-annual-overview/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/export-annual-overview/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/export-annual-overview/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/export-annual-overview/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/export-annual-overview/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/export-annual-overview/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/export-annual-overview/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/export-annual-overview/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/export-annual-overview/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/export-annual-overview/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/export-annual-overview/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/export-annual-overview/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/export-annual-overview/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/export-annual-overview/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/export-annual-overview/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/export-annual-overview/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/export-annual-overview/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/export-annual-overview/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/export-annual-overview/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/export-annual-overview/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/export-annual-overview/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/export-annual-overview/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/export-annual-overview/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/export-annual-overview/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/export-annual-overview/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/export-annual-overview/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_ExportRib_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
BODY json

{}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib" {:headers {:user-agent ""
                                                                                                                   :x-bunq-client-authentication ""}
                                                                                                         :content-type :json})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib"

	payload := strings.NewReader("{}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/export-rib HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 2

{}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{}")
  .asString();
const data = JSON.stringify({});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/export-rib',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{  };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib', [
  'body' => '{}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib' -Method POST -Headers $headers -ContentType 'application/json' -Body '{}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib' -Method POST -Headers $headers -ContentType 'application/json' -Body '{}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/export-rib", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib"

payload = {}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib"

payload <- "{}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/export-rib') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib";

    let payload = json!({});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{}'
echo '{}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_ExportRib_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId" {:headers {:user-agent ""
                                                                                                                             :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId"]
                                                       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}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_ExportRib_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib" {:headers {:user-agent ""
                                                                                                                  :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/export-rib HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/export-rib',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/export-rib", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/export-rib') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_ExportRib_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId" {:headers {:user-agent ""
                                                                                                                          :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/export-rib/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_ExportStatementCard_for_User_Card
{{baseUrl}}/user/:userID/card/:cardID/export-statement-card
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
cardID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card" {:headers {:user-agent ""
                                                                                                     :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/card/:cardID/export-statement-card HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/card/:cardID/export-statement-card',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/card/:cardID/export-statement-card"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/card/:cardID/export-statement-card');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/card/:cardID/export-statement-card');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/card/:cardID/export-statement-card", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/card/:cardID/export-statement-card') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/card/:cardID/export-statement-card \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/card/:cardID/export-statement-card \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/card/:cardID/export-statement-card
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_ExportStatementCard_for_User_Card
{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
cardID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:itemId" {:headers {:user-agent ""
                                                                                                             :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/card/:cardID/export-statement-card/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/card/:cardID/export-statement-card/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/card/:cardID/export-statement-card/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/card/:cardID/export-statement-card/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_ExportStatementCardCsv_for_User_Card
{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
cardID
BODY json

{
  "date_end": "",
  "date_start": "",
  "regional_format": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"date_end\": \"\",\n  \"date_start\": \"\",\n  \"regional_format\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv" {:headers {:user-agent ""
                                                                                                          :x-bunq-client-authentication ""}
                                                                                                :content-type :json
                                                                                                :form-params {:date_end ""
                                                                                                              :date_start ""
                                                                                                              :regional_format ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"date_end\": \"\",\n  \"date_start\": \"\",\n  \"regional_format\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"date_end\": \"\",\n  \"date_start\": \"\",\n  \"regional_format\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"date_end\": \"\",\n  \"date_start\": \"\",\n  \"regional_format\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv"

	payload := strings.NewReader("{\n  \"date_end\": \"\",\n  \"date_start\": \"\",\n  \"regional_format\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/card/:cardID/export-statement-card-csv HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 65

{
  "date_end": "",
  "date_start": "",
  "regional_format": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"date_end\": \"\",\n  \"date_start\": \"\",\n  \"regional_format\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"date_end\": \"\",\n  \"date_start\": \"\",\n  \"regional_format\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"date_end\": \"\",\n  \"date_start\": \"\",\n  \"regional_format\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"date_end\": \"\",\n  \"date_start\": \"\",\n  \"regional_format\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  date_end: '',
  date_start: '',
  regional_format: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {date_end: '', date_start: '', regional_format: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"date_end":"","date_start":"","regional_format":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "date_end": "",\n  "date_start": "",\n  "regional_format": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"date_end\": \"\",\n  \"date_start\": \"\",\n  \"regional_format\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/card/:cardID/export-statement-card-csv',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({date_end: '', date_start: '', regional_format: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {date_end: '', date_start: '', regional_format: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  date_end: '',
  date_start: '',
  regional_format: ''
});

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}}/user/:userID/card/:cardID/export-statement-card-csv',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {date_end: '', date_start: '', regional_format: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"date_end":"","date_start":"","regional_format":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"date_end": @"",
                              @"date_start": @"",
                              @"regional_format": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"date_end\": \"\",\n  \"date_start\": \"\",\n  \"regional_format\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'date_end' => '',
    'date_start' => '',
    'regional_format' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv', [
  'body' => '{
  "date_end": "",
  "date_start": "",
  "regional_format": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'date_end' => '',
  'date_start' => '',
  'regional_format' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'date_end' => '',
  'date_start' => '',
  'regional_format' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "date_end": "",
  "date_start": "",
  "regional_format": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "date_end": "",
  "date_start": "",
  "regional_format": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"date_end\": \"\",\n  \"date_start\": \"\",\n  \"regional_format\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/card/:cardID/export-statement-card-csv", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv"

payload = {
    "date_end": "",
    "date_start": "",
    "regional_format": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv"

payload <- "{\n  \"date_end\": \"\",\n  \"date_start\": \"\",\n  \"regional_format\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"date_end\": \"\",\n  \"date_start\": \"\",\n  \"regional_format\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/card/:cardID/export-statement-card-csv') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"date_end\": \"\",\n  \"date_start\": \"\",\n  \"regional_format\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv";

    let payload = json!({
        "date_end": "",
        "date_start": "",
        "regional_format": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "date_end": "",
  "date_start": "",
  "regional_format": ""
}'
echo '{
  "date_end": "",
  "date_start": "",
  "regional_format": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "date_end": "",\n  "date_start": "",\n  "regional_format": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "date_end": "",
  "date_start": "",
  "regional_format": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_ExportStatementCardCsv_for_User_Card
{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
cardID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId" {:headers {:user-agent ""
                                                                                                                    :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/card/:cardID/export-statement-card-csv/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/card/:cardID/export-statement-card-csv/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId"]
                                                       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}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/card/:cardID/export-statement-card-csv/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/card/:cardID/export-statement-card-csv/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_ExportStatementCardCsv_for_User_Card
{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
cardID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv" {:headers {:user-agent ""
                                                                                                         :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/card/:cardID/export-statement-card-csv HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/card/:cardID/export-statement-card-csv',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/card/:cardID/export-statement-card-csv", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/card/:cardID/export-statement-card-csv') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_ExportStatementCardCsv_for_User_Card
{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
cardID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId" {:headers {:user-agent ""
                                                                                                                 :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/card/:cardID/export-statement-card-csv/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/card/:cardID/export-statement-card-csv/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/card/:cardID/export-statement-card-csv/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/card/:cardID/export-statement-card-csv/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-csv/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_ExportStatementCardPdf_for_User_Card
{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
cardID
BODY json

{
  "date_end": "",
  "date_start": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"date_end\": \"\",\n  \"date_start\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf" {:headers {:user-agent ""
                                                                                                          :x-bunq-client-authentication ""}
                                                                                                :content-type :json
                                                                                                :form-params {:date_end ""
                                                                                                              :date_start ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"date_end\": \"\",\n  \"date_start\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"date_end\": \"\",\n  \"date_start\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"date_end\": \"\",\n  \"date_start\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf"

	payload := strings.NewReader("{\n  \"date_end\": \"\",\n  \"date_start\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/card/:cardID/export-statement-card-pdf HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 40

{
  "date_end": "",
  "date_start": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"date_end\": \"\",\n  \"date_start\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"date_end\": \"\",\n  \"date_start\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"date_end\": \"\",\n  \"date_start\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"date_end\": \"\",\n  \"date_start\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  date_end: '',
  date_start: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {date_end: '', date_start: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"date_end":"","date_start":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "date_end": "",\n  "date_start": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"date_end\": \"\",\n  \"date_start\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/card/:cardID/export-statement-card-pdf',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({date_end: '', date_start: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {date_end: '', date_start: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  date_end: '',
  date_start: ''
});

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}}/user/:userID/card/:cardID/export-statement-card-pdf',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {date_end: '', date_start: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"date_end":"","date_start":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"date_end": @"",
                              @"date_start": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"date_end\": \"\",\n  \"date_start\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'date_end' => '',
    'date_start' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf', [
  'body' => '{
  "date_end": "",
  "date_start": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'date_end' => '',
  'date_start' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'date_end' => '',
  'date_start' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "date_end": "",
  "date_start": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "date_end": "",
  "date_start": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"date_end\": \"\",\n  \"date_start\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/card/:cardID/export-statement-card-pdf", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf"

payload = {
    "date_end": "",
    "date_start": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf"

payload <- "{\n  \"date_end\": \"\",\n  \"date_start\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"date_end\": \"\",\n  \"date_start\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/card/:cardID/export-statement-card-pdf') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"date_end\": \"\",\n  \"date_start\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf";

    let payload = json!({
        "date_end": "",
        "date_start": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "date_end": "",
  "date_start": ""
}'
echo '{
  "date_end": "",
  "date_start": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "date_end": "",\n  "date_start": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "date_end": "",
  "date_start": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_ExportStatementCardPdf_for_User_Card
{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
cardID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId" {:headers {:user-agent ""
                                                                                                                    :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/card/:cardID/export-statement-card-pdf/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/card/:cardID/export-statement-card-pdf/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId"]
                                                       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}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/card/:cardID/export-statement-card-pdf/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/card/:cardID/export-statement-card-pdf/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_ExportStatementCardPdf_for_User_Card
{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
cardID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf" {:headers {:user-agent ""
                                                                                                         :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/card/:cardID/export-statement-card-pdf HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/card/:cardID/export-statement-card-pdf',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/card/:cardID/export-statement-card-pdf", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/card/:cardID/export-statement-card-pdf') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_ExportStatementCardPdf_for_User_Card
{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
cardID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId" {:headers {:user-agent ""
                                                                                                                 :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/card/:cardID/export-statement-card-pdf/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/card/:cardID/export-statement-card-pdf/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/card/:cardID/export-statement-card-pdf/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/card/:cardID/export-statement-card-pdf/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/card/:cardID/export-statement-card-pdf/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_FeatureAnnouncement_for_User
{{baseUrl}}/user/:userID/feature-announcement/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/feature-announcement/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/feature-announcement/:itemId" {:headers {:user-agent ""
                                                                                               :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/feature-announcement/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/feature-announcement/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/feature-announcement/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/feature-announcement/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/feature-announcement/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/feature-announcement/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/feature-announcement/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/feature-announcement/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/feature-announcement/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/feature-announcement/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/feature-announcement/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/feature-announcement/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/feature-announcement/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/feature-announcement/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/feature-announcement/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/feature-announcement/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/feature-announcement/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/feature-announcement/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/feature-announcement/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/feature-announcement/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/feature-announcement/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/feature-announcement/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/feature-announcement/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/feature-announcement/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/feature-announcement/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/feature-announcement/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/feature-announcement/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/feature-announcement/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/feature-announcement/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/feature-announcement/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/feature-announcement/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/feature-announcement/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/feature-announcement/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/feature-announcement/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/feature-announcement/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/feature-announcement/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/feature-announcement/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_GeneratedCvc2_for_User_Card
{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
cardID
BODY json

{
  "type": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"type\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2" {:headers {:user-agent ""
                                                                                               :x-bunq-client-authentication ""}
                                                                                     :content-type :json
                                                                                     :form-params {:type ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"type\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"type\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"type\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2"

	payload := strings.NewReader("{\n  \"type\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/card/:cardID/generated-cvc2 HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 16

{
  "type": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"type\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"type\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"type\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"type\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  type: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {type: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"type":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "type": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"type\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/card/:cardID/generated-cvc2',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({type: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {type: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  type: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {type: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"type":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"type": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"type\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'type' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2', [
  'body' => '{
  "type": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'type' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'type' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "type": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "type": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"type\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/card/:cardID/generated-cvc2", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2"

payload = { "type": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2"

payload <- "{\n  \"type\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"type\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/card/:cardID/generated-cvc2') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"type\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2";

    let payload = json!({"type": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/card/:cardID/generated-cvc2 \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "type": ""
}'
echo '{
  "type": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/card/:cardID/generated-cvc2 \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "type": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/card/:cardID/generated-cvc2
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["type": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_GeneratedCvc2_for_User_Card
{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
cardID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2" {:headers {:user-agent ""
                                                                                              :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/card/:cardID/generated-cvc2 HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/card/:cardID/generated-cvc2',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/card/:cardID/generated-cvc2", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/card/:cardID/generated-cvc2') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/card/:cardID/generated-cvc2 \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/card/:cardID/generated-cvc2 \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/card/:cardID/generated-cvc2
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_GeneratedCvc2_for_User_Card
{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
cardID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId" {:headers {:user-agent ""
                                                                                                      :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/card/:cardID/generated-cvc2/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/card/:cardID/generated-cvc2/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/card/:cardID/generated-cvc2/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/card/:cardID/generated-cvc2/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_GeneratedCvc2_for_User_Card
{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
cardID
itemId
BODY json

{
  "type": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"type\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId" {:headers {:user-agent ""
                                                                                                      :x-bunq-client-authentication ""}
                                                                                            :content-type :json
                                                                                            :form-params {:type ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"type\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"type\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"type\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId"

	payload := strings.NewReader("{\n  \"type\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/card/:cardID/generated-cvc2/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 16

{
  "type": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"type\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"type\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"type\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"type\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  type: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {type: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"type":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "type": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"type\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/card/:cardID/generated-cvc2/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({type: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {type: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  type: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {type: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"type":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"type": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"type\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'type' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId', [
  'body' => '{
  "type": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'type' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'type' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "type": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "type": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"type\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/card/:cardID/generated-cvc2/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId"

payload = { "type": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId"

payload <- "{\n  \"type\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"type\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/card/:cardID/generated-cvc2/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"type\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId";

    let payload = json!({"type": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "type": ""
}'
echo '{
  "type": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "type": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["type": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/card/:cardID/generated-cvc2/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_IdealMerchantTransaction_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
BODY json

{
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "amount_guaranteed": {
    "currency": "",
    "value": ""
  },
  "amount_requested": {},
  "counterparty_alias": {},
  "expiration": "",
  "issuer": "",
  "issuer_authentication_url": "",
  "issuer_name": "",
  "monetary_account_id": 0,
  "purchase_identifier": "",
  "status": "",
  "status_timestamp": "",
  "transaction_identifier": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_guaranteed\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_requested\": {},\n  \"counterparty_alias\": {},\n  \"expiration\": \"\",\n  \"issuer\": \"\",\n  \"issuer_authentication_url\": \"\",\n  \"issuer_name\": \"\",\n  \"monetary_account_id\": 0,\n  \"purchase_identifier\": \"\",\n  \"status\": \"\",\n  \"status_timestamp\": \"\",\n  \"transaction_identifier\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction" {:headers {:user-agent ""
                                                                                                                                   :x-bunq-client-authentication ""}
                                                                                                                         :content-type :json
                                                                                                                         :form-params {:alias {:avatar {:anchor_uuid ""
                                                                                                                                                        :image [{:attachment_public_uuid ""
                                                                                                                                                                 :content_type ""
                                                                                                                                                                 :height 0
                                                                                                                                                                 :width 0}]
                                                                                                                                                        :style ""
                                                                                                                                                        :uuid ""}
                                                                                                                                               :bunq_me {:name ""
                                                                                                                                                         :service ""
                                                                                                                                                         :type ""
                                                                                                                                                         :value ""}
                                                                                                                                               :country ""
                                                                                                                                               :display_name ""
                                                                                                                                               :iban ""
                                                                                                                                               :is_light false
                                                                                                                                               :label_user {:avatar {}
                                                                                                                                                            :country ""
                                                                                                                                                            :display_name ""
                                                                                                                                                            :public_nick_name ""
                                                                                                                                                            :uuid ""}
                                                                                                                                               :merchant_category_code ""
                                                                                                                                               :swift_account_number ""
                                                                                                                                               :swift_bic ""
                                                                                                                                               :transferwise_account_number ""
                                                                                                                                               :transferwise_bank_code ""}
                                                                                                                                       :amount_guaranteed {:currency ""
                                                                                                                                                           :value ""}
                                                                                                                                       :amount_requested {}
                                                                                                                                       :counterparty_alias {}
                                                                                                                                       :expiration ""
                                                                                                                                       :issuer ""
                                                                                                                                       :issuer_authentication_url ""
                                                                                                                                       :issuer_name ""
                                                                                                                                       :monetary_account_id 0
                                                                                                                                       :purchase_identifier ""
                                                                                                                                       :status ""
                                                                                                                                       :status_timestamp ""
                                                                                                                                       :transaction_identifier ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_guaranteed\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_requested\": {},\n  \"counterparty_alias\": {},\n  \"expiration\": \"\",\n  \"issuer\": \"\",\n  \"issuer_authentication_url\": \"\",\n  \"issuer_name\": \"\",\n  \"monetary_account_id\": 0,\n  \"purchase_identifier\": \"\",\n  \"status\": \"\",\n  \"status_timestamp\": \"\",\n  \"transaction_identifier\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_guaranteed\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_requested\": {},\n  \"counterparty_alias\": {},\n  \"expiration\": \"\",\n  \"issuer\": \"\",\n  \"issuer_authentication_url\": \"\",\n  \"issuer_name\": \"\",\n  \"monetary_account_id\": 0,\n  \"purchase_identifier\": \"\",\n  \"status\": \"\",\n  \"status_timestamp\": \"\",\n  \"transaction_identifier\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_guaranteed\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_requested\": {},\n  \"counterparty_alias\": {},\n  \"expiration\": \"\",\n  \"issuer\": \"\",\n  \"issuer_authentication_url\": \"\",\n  \"issuer_name\": \"\",\n  \"monetary_account_id\": 0,\n  \"purchase_identifier\": \"\",\n  \"status\": \"\",\n  \"status_timestamp\": \"\",\n  \"transaction_identifier\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction"

	payload := strings.NewReader("{\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_guaranteed\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_requested\": {},\n  \"counterparty_alias\": {},\n  \"expiration\": \"\",\n  \"issuer\": \"\",\n  \"issuer_authentication_url\": \"\",\n  \"issuer_name\": \"\",\n  \"monetary_account_id\": 0,\n  \"purchase_identifier\": \"\",\n  \"status\": \"\",\n  \"status_timestamp\": \"\",\n  \"transaction_identifier\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 1088

{
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "amount_guaranteed": {
    "currency": "",
    "value": ""
  },
  "amount_requested": {},
  "counterparty_alias": {},
  "expiration": "",
  "issuer": "",
  "issuer_authentication_url": "",
  "issuer_name": "",
  "monetary_account_id": 0,
  "purchase_identifier": "",
  "status": "",
  "status_timestamp": "",
  "transaction_identifier": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_guaranteed\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_requested\": {},\n  \"counterparty_alias\": {},\n  \"expiration\": \"\",\n  \"issuer\": \"\",\n  \"issuer_authentication_url\": \"\",\n  \"issuer_name\": \"\",\n  \"monetary_account_id\": 0,\n  \"purchase_identifier\": \"\",\n  \"status\": \"\",\n  \"status_timestamp\": \"\",\n  \"transaction_identifier\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_guaranteed\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_requested\": {},\n  \"counterparty_alias\": {},\n  \"expiration\": \"\",\n  \"issuer\": \"\",\n  \"issuer_authentication_url\": \"\",\n  \"issuer_name\": \"\",\n  \"monetary_account_id\": 0,\n  \"purchase_identifier\": \"\",\n  \"status\": \"\",\n  \"status_timestamp\": \"\",\n  \"transaction_identifier\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_guaranteed\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_requested\": {},\n  \"counterparty_alias\": {},\n  \"expiration\": \"\",\n  \"issuer\": \"\",\n  \"issuer_authentication_url\": \"\",\n  \"issuer_name\": \"\",\n  \"monetary_account_id\": 0,\n  \"purchase_identifier\": \"\",\n  \"status\": \"\",\n  \"status_timestamp\": \"\",\n  \"transaction_identifier\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_guaranteed\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_requested\": {},\n  \"counterparty_alias\": {},\n  \"expiration\": \"\",\n  \"issuer\": \"\",\n  \"issuer_authentication_url\": \"\",\n  \"issuer_name\": \"\",\n  \"monetary_account_id\": 0,\n  \"purchase_identifier\": \"\",\n  \"status\": \"\",\n  \"status_timestamp\": \"\",\n  \"transaction_identifier\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  alias: {
    avatar: {
      anchor_uuid: '',
      image: [
        {
          attachment_public_uuid: '',
          content_type: '',
          height: 0,
          width: 0
        }
      ],
      style: '',
      uuid: ''
    },
    bunq_me: {
      name: '',
      service: '',
      type: '',
      value: ''
    },
    country: '',
    display_name: '',
    iban: '',
    is_light: false,
    label_user: {
      avatar: {},
      country: '',
      display_name: '',
      public_nick_name: '',
      uuid: ''
    },
    merchant_category_code: '',
    swift_account_number: '',
    swift_bic: '',
    transferwise_account_number: '',
    transferwise_bank_code: ''
  },
  amount_guaranteed: {
    currency: '',
    value: ''
  },
  amount_requested: {},
  counterparty_alias: {},
  expiration: '',
  issuer: '',
  issuer_authentication_url: '',
  issuer_name: '',
  monetary_account_id: 0,
  purchase_identifier: '',
  status: '',
  status_timestamp: '',
  transaction_identifier: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    alias: {
      avatar: {
        anchor_uuid: '',
        image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
        style: '',
        uuid: ''
      },
      bunq_me: {name: '', service: '', type: '', value: ''},
      country: '',
      display_name: '',
      iban: '',
      is_light: false,
      label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
      merchant_category_code: '',
      swift_account_number: '',
      swift_bic: '',
      transferwise_account_number: '',
      transferwise_bank_code: ''
    },
    amount_guaranteed: {currency: '', value: ''},
    amount_requested: {},
    counterparty_alias: {},
    expiration: '',
    issuer: '',
    issuer_authentication_url: '',
    issuer_name: '',
    monetary_account_id: 0,
    purchase_identifier: '',
    status: '',
    status_timestamp: '',
    transaction_identifier: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"amount_guaranteed":{"currency":"","value":""},"amount_requested":{},"counterparty_alias":{},"expiration":"","issuer":"","issuer_authentication_url":"","issuer_name":"","monetary_account_id":0,"purchase_identifier":"","status":"","status_timestamp":"","transaction_identifier":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "alias": {\n    "avatar": {\n      "anchor_uuid": "",\n      "image": [\n        {\n          "attachment_public_uuid": "",\n          "content_type": "",\n          "height": 0,\n          "width": 0\n        }\n      ],\n      "style": "",\n      "uuid": ""\n    },\n    "bunq_me": {\n      "name": "",\n      "service": "",\n      "type": "",\n      "value": ""\n    },\n    "country": "",\n    "display_name": "",\n    "iban": "",\n    "is_light": false,\n    "label_user": {\n      "avatar": {},\n      "country": "",\n      "display_name": "",\n      "public_nick_name": "",\n      "uuid": ""\n    },\n    "merchant_category_code": "",\n    "swift_account_number": "",\n    "swift_bic": "",\n    "transferwise_account_number": "",\n    "transferwise_bank_code": ""\n  },\n  "amount_guaranteed": {\n    "currency": "",\n    "value": ""\n  },\n  "amount_requested": {},\n  "counterparty_alias": {},\n  "expiration": "",\n  "issuer": "",\n  "issuer_authentication_url": "",\n  "issuer_name": "",\n  "monetary_account_id": 0,\n  "purchase_identifier": "",\n  "status": "",\n  "status_timestamp": "",\n  "transaction_identifier": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_guaranteed\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_requested\": {},\n  \"counterparty_alias\": {},\n  \"expiration\": \"\",\n  \"issuer\": \"\",\n  \"issuer_authentication_url\": \"\",\n  \"issuer_name\": \"\",\n  \"monetary_account_id\": 0,\n  \"purchase_identifier\": \"\",\n  \"status\": \"\",\n  \"status_timestamp\": \"\",\n  \"transaction_identifier\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  alias: {
    avatar: {
      anchor_uuid: '',
      image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
      style: '',
      uuid: ''
    },
    bunq_me: {name: '', service: '', type: '', value: ''},
    country: '',
    display_name: '',
    iban: '',
    is_light: false,
    label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
    merchant_category_code: '',
    swift_account_number: '',
    swift_bic: '',
    transferwise_account_number: '',
    transferwise_bank_code: ''
  },
  amount_guaranteed: {currency: '', value: ''},
  amount_requested: {},
  counterparty_alias: {},
  expiration: '',
  issuer: '',
  issuer_authentication_url: '',
  issuer_name: '',
  monetary_account_id: 0,
  purchase_identifier: '',
  status: '',
  status_timestamp: '',
  transaction_identifier: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    alias: {
      avatar: {
        anchor_uuid: '',
        image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
        style: '',
        uuid: ''
      },
      bunq_me: {name: '', service: '', type: '', value: ''},
      country: '',
      display_name: '',
      iban: '',
      is_light: false,
      label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
      merchant_category_code: '',
      swift_account_number: '',
      swift_bic: '',
      transferwise_account_number: '',
      transferwise_bank_code: ''
    },
    amount_guaranteed: {currency: '', value: ''},
    amount_requested: {},
    counterparty_alias: {},
    expiration: '',
    issuer: '',
    issuer_authentication_url: '',
    issuer_name: '',
    monetary_account_id: 0,
    purchase_identifier: '',
    status: '',
    status_timestamp: '',
    transaction_identifier: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  alias: {
    avatar: {
      anchor_uuid: '',
      image: [
        {
          attachment_public_uuid: '',
          content_type: '',
          height: 0,
          width: 0
        }
      ],
      style: '',
      uuid: ''
    },
    bunq_me: {
      name: '',
      service: '',
      type: '',
      value: ''
    },
    country: '',
    display_name: '',
    iban: '',
    is_light: false,
    label_user: {
      avatar: {},
      country: '',
      display_name: '',
      public_nick_name: '',
      uuid: ''
    },
    merchant_category_code: '',
    swift_account_number: '',
    swift_bic: '',
    transferwise_account_number: '',
    transferwise_bank_code: ''
  },
  amount_guaranteed: {
    currency: '',
    value: ''
  },
  amount_requested: {},
  counterparty_alias: {},
  expiration: '',
  issuer: '',
  issuer_authentication_url: '',
  issuer_name: '',
  monetary_account_id: 0,
  purchase_identifier: '',
  status: '',
  status_timestamp: '',
  transaction_identifier: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    alias: {
      avatar: {
        anchor_uuid: '',
        image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
        style: '',
        uuid: ''
      },
      bunq_me: {name: '', service: '', type: '', value: ''},
      country: '',
      display_name: '',
      iban: '',
      is_light: false,
      label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
      merchant_category_code: '',
      swift_account_number: '',
      swift_bic: '',
      transferwise_account_number: '',
      transferwise_bank_code: ''
    },
    amount_guaranteed: {currency: '', value: ''},
    amount_requested: {},
    counterparty_alias: {},
    expiration: '',
    issuer: '',
    issuer_authentication_url: '',
    issuer_name: '',
    monetary_account_id: 0,
    purchase_identifier: '',
    status: '',
    status_timestamp: '',
    transaction_identifier: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"amount_guaranteed":{"currency":"","value":""},"amount_requested":{},"counterparty_alias":{},"expiration":"","issuer":"","issuer_authentication_url":"","issuer_name":"","monetary_account_id":0,"purchase_identifier":"","status":"","status_timestamp":"","transaction_identifier":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"alias": @{ @"avatar": @{ @"anchor_uuid": @"", @"image": @[ @{ @"attachment_public_uuid": @"", @"content_type": @"", @"height": @0, @"width": @0 } ], @"style": @"", @"uuid": @"" }, @"bunq_me": @{ @"name": @"", @"service": @"", @"type": @"", @"value": @"" }, @"country": @"", @"display_name": @"", @"iban": @"", @"is_light": @NO, @"label_user": @{ @"avatar": @{  }, @"country": @"", @"display_name": @"", @"public_nick_name": @"", @"uuid": @"" }, @"merchant_category_code": @"", @"swift_account_number": @"", @"swift_bic": @"", @"transferwise_account_number": @"", @"transferwise_bank_code": @"" },
                              @"amount_guaranteed": @{ @"currency": @"", @"value": @"" },
                              @"amount_requested": @{  },
                              @"counterparty_alias": @{  },
                              @"expiration": @"",
                              @"issuer": @"",
                              @"issuer_authentication_url": @"",
                              @"issuer_name": @"",
                              @"monetary_account_id": @0,
                              @"purchase_identifier": @"",
                              @"status": @"",
                              @"status_timestamp": @"",
                              @"transaction_identifier": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_guaranteed\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_requested\": {},\n  \"counterparty_alias\": {},\n  \"expiration\": \"\",\n  \"issuer\": \"\",\n  \"issuer_authentication_url\": \"\",\n  \"issuer_name\": \"\",\n  \"monetary_account_id\": 0,\n  \"purchase_identifier\": \"\",\n  \"status\": \"\",\n  \"status_timestamp\": \"\",\n  \"transaction_identifier\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'alias' => [
        'avatar' => [
                'anchor_uuid' => '',
                'image' => [
                                [
                                                                'attachment_public_uuid' => '',
                                                                'content_type' => '',
                                                                'height' => 0,
                                                                'width' => 0
                                ]
                ],
                'style' => '',
                'uuid' => ''
        ],
        'bunq_me' => [
                'name' => '',
                'service' => '',
                'type' => '',
                'value' => ''
        ],
        'country' => '',
        'display_name' => '',
        'iban' => '',
        'is_light' => null,
        'label_user' => [
                'avatar' => [
                                
                ],
                'country' => '',
                'display_name' => '',
                'public_nick_name' => '',
                'uuid' => ''
        ],
        'merchant_category_code' => '',
        'swift_account_number' => '',
        'swift_bic' => '',
        'transferwise_account_number' => '',
        'transferwise_bank_code' => ''
    ],
    'amount_guaranteed' => [
        'currency' => '',
        'value' => ''
    ],
    'amount_requested' => [
        
    ],
    'counterparty_alias' => [
        
    ],
    'expiration' => '',
    'issuer' => '',
    'issuer_authentication_url' => '',
    'issuer_name' => '',
    'monetary_account_id' => 0,
    'purchase_identifier' => '',
    'status' => '',
    'status_timestamp' => '',
    'transaction_identifier' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction', [
  'body' => '{
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "amount_guaranteed": {
    "currency": "",
    "value": ""
  },
  "amount_requested": {},
  "counterparty_alias": {},
  "expiration": "",
  "issuer": "",
  "issuer_authentication_url": "",
  "issuer_name": "",
  "monetary_account_id": 0,
  "purchase_identifier": "",
  "status": "",
  "status_timestamp": "",
  "transaction_identifier": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'alias' => [
    'avatar' => [
        'anchor_uuid' => '',
        'image' => [
                [
                                'attachment_public_uuid' => '',
                                'content_type' => '',
                                'height' => 0,
                                'width' => 0
                ]
        ],
        'style' => '',
        'uuid' => ''
    ],
    'bunq_me' => [
        'name' => '',
        'service' => '',
        'type' => '',
        'value' => ''
    ],
    'country' => '',
    'display_name' => '',
    'iban' => '',
    'is_light' => null,
    'label_user' => [
        'avatar' => [
                
        ],
        'country' => '',
        'display_name' => '',
        'public_nick_name' => '',
        'uuid' => ''
    ],
    'merchant_category_code' => '',
    'swift_account_number' => '',
    'swift_bic' => '',
    'transferwise_account_number' => '',
    'transferwise_bank_code' => ''
  ],
  'amount_guaranteed' => [
    'currency' => '',
    'value' => ''
  ],
  'amount_requested' => [
    
  ],
  'counterparty_alias' => [
    
  ],
  'expiration' => '',
  'issuer' => '',
  'issuer_authentication_url' => '',
  'issuer_name' => '',
  'monetary_account_id' => 0,
  'purchase_identifier' => '',
  'status' => '',
  'status_timestamp' => '',
  'transaction_identifier' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'alias' => [
    'avatar' => [
        'anchor_uuid' => '',
        'image' => [
                [
                                'attachment_public_uuid' => '',
                                'content_type' => '',
                                'height' => 0,
                                'width' => 0
                ]
        ],
        'style' => '',
        'uuid' => ''
    ],
    'bunq_me' => [
        'name' => '',
        'service' => '',
        'type' => '',
        'value' => ''
    ],
    'country' => '',
    'display_name' => '',
    'iban' => '',
    'is_light' => null,
    'label_user' => [
        'avatar' => [
                
        ],
        'country' => '',
        'display_name' => '',
        'public_nick_name' => '',
        'uuid' => ''
    ],
    'merchant_category_code' => '',
    'swift_account_number' => '',
    'swift_bic' => '',
    'transferwise_account_number' => '',
    'transferwise_bank_code' => ''
  ],
  'amount_guaranteed' => [
    'currency' => '',
    'value' => ''
  ],
  'amount_requested' => [
    
  ],
  'counterparty_alias' => [
    
  ],
  'expiration' => '',
  'issuer' => '',
  'issuer_authentication_url' => '',
  'issuer_name' => '',
  'monetary_account_id' => 0,
  'purchase_identifier' => '',
  'status' => '',
  'status_timestamp' => '',
  'transaction_identifier' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "amount_guaranteed": {
    "currency": "",
    "value": ""
  },
  "amount_requested": {},
  "counterparty_alias": {},
  "expiration": "",
  "issuer": "",
  "issuer_authentication_url": "",
  "issuer_name": "",
  "monetary_account_id": 0,
  "purchase_identifier": "",
  "status": "",
  "status_timestamp": "",
  "transaction_identifier": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "amount_guaranteed": {
    "currency": "",
    "value": ""
  },
  "amount_requested": {},
  "counterparty_alias": {},
  "expiration": "",
  "issuer": "",
  "issuer_authentication_url": "",
  "issuer_name": "",
  "monetary_account_id": 0,
  "purchase_identifier": "",
  "status": "",
  "status_timestamp": "",
  "transaction_identifier": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_guaranteed\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_requested\": {},\n  \"counterparty_alias\": {},\n  \"expiration\": \"\",\n  \"issuer\": \"\",\n  \"issuer_authentication_url\": \"\",\n  \"issuer_name\": \"\",\n  \"monetary_account_id\": 0,\n  \"purchase_identifier\": \"\",\n  \"status\": \"\",\n  \"status_timestamp\": \"\",\n  \"transaction_identifier\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction"

payload = {
    "alias": {
        "avatar": {
            "anchor_uuid": "",
            "image": [
                {
                    "attachment_public_uuid": "",
                    "content_type": "",
                    "height": 0,
                    "width": 0
                }
            ],
            "style": "",
            "uuid": ""
        },
        "bunq_me": {
            "name": "",
            "service": "",
            "type": "",
            "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": False,
        "label_user": {
            "avatar": {},
            "country": "",
            "display_name": "",
            "public_nick_name": "",
            "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
    },
    "amount_guaranteed": {
        "currency": "",
        "value": ""
    },
    "amount_requested": {},
    "counterparty_alias": {},
    "expiration": "",
    "issuer": "",
    "issuer_authentication_url": "",
    "issuer_name": "",
    "monetary_account_id": 0,
    "purchase_identifier": "",
    "status": "",
    "status_timestamp": "",
    "transaction_identifier": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction"

payload <- "{\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_guaranteed\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_requested\": {},\n  \"counterparty_alias\": {},\n  \"expiration\": \"\",\n  \"issuer\": \"\",\n  \"issuer_authentication_url\": \"\",\n  \"issuer_name\": \"\",\n  \"monetary_account_id\": 0,\n  \"purchase_identifier\": \"\",\n  \"status\": \"\",\n  \"status_timestamp\": \"\",\n  \"transaction_identifier\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_guaranteed\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_requested\": {},\n  \"counterparty_alias\": {},\n  \"expiration\": \"\",\n  \"issuer\": \"\",\n  \"issuer_authentication_url\": \"\",\n  \"issuer_name\": \"\",\n  \"monetary_account_id\": 0,\n  \"purchase_identifier\": \"\",\n  \"status\": \"\",\n  \"status_timestamp\": \"\",\n  \"transaction_identifier\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_guaranteed\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_requested\": {},\n  \"counterparty_alias\": {},\n  \"expiration\": \"\",\n  \"issuer\": \"\",\n  \"issuer_authentication_url\": \"\",\n  \"issuer_name\": \"\",\n  \"monetary_account_id\": 0,\n  \"purchase_identifier\": \"\",\n  \"status\": \"\",\n  \"status_timestamp\": \"\",\n  \"transaction_identifier\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction";

    let payload = json!({
        "alias": json!({
            "avatar": json!({
                "anchor_uuid": "",
                "image": (
                    json!({
                        "attachment_public_uuid": "",
                        "content_type": "",
                        "height": 0,
                        "width": 0
                    })
                ),
                "style": "",
                "uuid": ""
            }),
            "bunq_me": json!({
                "name": "",
                "service": "",
                "type": "",
                "value": ""
            }),
            "country": "",
            "display_name": "",
            "iban": "",
            "is_light": false,
            "label_user": json!({
                "avatar": json!({}),
                "country": "",
                "display_name": "",
                "public_nick_name": "",
                "uuid": ""
            }),
            "merchant_category_code": "",
            "swift_account_number": "",
            "swift_bic": "",
            "transferwise_account_number": "",
            "transferwise_bank_code": ""
        }),
        "amount_guaranteed": json!({
            "currency": "",
            "value": ""
        }),
        "amount_requested": json!({}),
        "counterparty_alias": json!({}),
        "expiration": "",
        "issuer": "",
        "issuer_authentication_url": "",
        "issuer_name": "",
        "monetary_account_id": 0,
        "purchase_identifier": "",
        "status": "",
        "status_timestamp": "",
        "transaction_identifier": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "amount_guaranteed": {
    "currency": "",
    "value": ""
  },
  "amount_requested": {},
  "counterparty_alias": {},
  "expiration": "",
  "issuer": "",
  "issuer_authentication_url": "",
  "issuer_name": "",
  "monetary_account_id": 0,
  "purchase_identifier": "",
  "status": "",
  "status_timestamp": "",
  "transaction_identifier": ""
}'
echo '{
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "amount_guaranteed": {
    "currency": "",
    "value": ""
  },
  "amount_requested": {},
  "counterparty_alias": {},
  "expiration": "",
  "issuer": "",
  "issuer_authentication_url": "",
  "issuer_name": "",
  "monetary_account_id": 0,
  "purchase_identifier": "",
  "status": "",
  "status_timestamp": "",
  "transaction_identifier": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "alias": {\n    "avatar": {\n      "anchor_uuid": "",\n      "image": [\n        {\n          "attachment_public_uuid": "",\n          "content_type": "",\n          "height": 0,\n          "width": 0\n        }\n      ],\n      "style": "",\n      "uuid": ""\n    },\n    "bunq_me": {\n      "name": "",\n      "service": "",\n      "type": "",\n      "value": ""\n    },\n    "country": "",\n    "display_name": "",\n    "iban": "",\n    "is_light": false,\n    "label_user": {\n      "avatar": {},\n      "country": "",\n      "display_name": "",\n      "public_nick_name": "",\n      "uuid": ""\n    },\n    "merchant_category_code": "",\n    "swift_account_number": "",\n    "swift_bic": "",\n    "transferwise_account_number": "",\n    "transferwise_bank_code": ""\n  },\n  "amount_guaranteed": {\n    "currency": "",\n    "value": ""\n  },\n  "amount_requested": {},\n  "counterparty_alias": {},\n  "expiration": "",\n  "issuer": "",\n  "issuer_authentication_url": "",\n  "issuer_name": "",\n  "monetary_account_id": 0,\n  "purchase_identifier": "",\n  "status": "",\n  "status_timestamp": "",\n  "transaction_identifier": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "alias": [
    "avatar": [
      "anchor_uuid": "",
      "image": [
        [
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        ]
      ],
      "style": "",
      "uuid": ""
    ],
    "bunq_me": [
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    ],
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": [
      "avatar": [],
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    ],
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  ],
  "amount_guaranteed": [
    "currency": "",
    "value": ""
  ],
  "amount_requested": [],
  "counterparty_alias": [],
  "expiration": "",
  "issuer": "",
  "issuer_authentication_url": "",
  "issuer_name": "",
  "monetary_account_id": 0,
  "purchase_identifier": "",
  "status": "",
  "status_timestamp": "",
  "transaction_identifier": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_IdealMerchantTransaction_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction" {:headers {:user-agent ""
                                                                                                                                  :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_IdealMerchantTransaction_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:itemId" {:headers {:user-agent ""
                                                                                                                                          :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_InsightPreferenceDate_for_User
{{baseUrl}}/user/:userID/insight-preference-date
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/insight-preference-date");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/insight-preference-date" {:headers {:user-agent ""
                                                                                          :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/insight-preference-date"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/insight-preference-date"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/insight-preference-date");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/insight-preference-date"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/insight-preference-date HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/insight-preference-date")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/insight-preference-date"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/insight-preference-date")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/insight-preference-date")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/insight-preference-date');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/insight-preference-date',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/insight-preference-date';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/insight-preference-date',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/insight-preference-date")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/insight-preference-date',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/insight-preference-date',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/insight-preference-date');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/insight-preference-date',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/insight-preference-date';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/insight-preference-date"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/insight-preference-date" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/insight-preference-date",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/insight-preference-date', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/insight-preference-date');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/insight-preference-date');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/insight-preference-date' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/insight-preference-date' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/insight-preference-date", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/insight-preference-date"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/insight-preference-date"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/insight-preference-date")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/insight-preference-date') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/insight-preference-date";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/insight-preference-date \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/insight-preference-date \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/insight-preference-date
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/insight-preference-date")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_Insights_for_User
{{baseUrl}}/user/:userID/insights
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/insights");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/insights" {:headers {:user-agent ""
                                                                           :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/insights"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/insights"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/insights");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/insights"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/insights HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/insights")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/insights"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/insights")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/insights")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/insights');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/insights',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/insights';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/insights',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/insights")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/insights',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/insights',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/insights');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/insights',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/insights';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/insights"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/insights" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/insights",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/insights', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/insights');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/insights');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/insights' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/insights' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/insights", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/insights"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/insights"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/insights")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/insights') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/insights";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/insights \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/insights \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/insights
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/insights")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_InsightsSearch_for_User
{{baseUrl}}/user/:userID/insights-search
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/insights-search");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/insights-search" {:headers {:user-agent ""
                                                                                  :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/insights-search"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/insights-search"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/insights-search");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/insights-search"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/insights-search HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/insights-search")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/insights-search"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/insights-search")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/insights-search")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/insights-search');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/insights-search',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/insights-search';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/insights-search',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/insights-search")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/insights-search',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/insights-search',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/insights-search');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/insights-search',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/insights-search';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/insights-search"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/insights-search" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/insights-search",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/insights-search', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/insights-search');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/insights-search');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/insights-search' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/insights-search' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/insights-search", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/insights-search"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/insights-search"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/insights-search")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/insights-search') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/insights-search";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/insights-search \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/insights-search \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/insights-search
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/insights-search")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_Installation
{{baseUrl}}/installation
HEADERS

User-Agent
X-Bunq-Client-Authentication
BODY json

{
  "client_public_key": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/installation");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"client_public_key\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/installation" {:headers {:user-agent ""
                                                                   :x-bunq-client-authentication ""}
                                                         :content-type :json
                                                         :form-params {:client_public_key ""}})
require "http/client"

url = "{{baseUrl}}/installation"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"client_public_key\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/installation"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"client_public_key\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/installation");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"client_public_key\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/installation"

	payload := strings.NewReader("{\n  \"client_public_key\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/installation HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 29

{
  "client_public_key": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/installation")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"client_public_key\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/installation"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"client_public_key\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"client_public_key\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/installation")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/installation")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"client_public_key\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  client_public_key: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/installation');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/installation',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {client_public_key: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/installation';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"client_public_key":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/installation',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "client_public_key": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"client_public_key\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/installation")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/installation',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({client_public_key: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/installation',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {client_public_key: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/installation');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  client_public_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: 'POST',
  url: '{{baseUrl}}/installation',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {client_public_key: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/installation';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"client_public_key":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"client_public_key": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/installation"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/installation" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"client_public_key\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/installation",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'client_public_key' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/installation', [
  'body' => '{
  "client_public_key": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/installation');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'client_public_key' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'client_public_key' => ''
]));
$request->setRequestUrl('{{baseUrl}}/installation');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/installation' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "client_public_key": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/installation' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "client_public_key": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"client_public_key\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/installation", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/installation"

payload = { "client_public_key": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/installation"

payload <- "{\n  \"client_public_key\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/installation")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"client_public_key\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/installation') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"client_public_key\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/installation";

    let payload = json!({"client_public_key": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/installation \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "client_public_key": ""
}'
echo '{
  "client_public_key": ""
}' |  \
  http POST {{baseUrl}}/installation \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "client_public_key": ""\n}' \
  --output-document \
  - {{baseUrl}}/installation
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["client_public_key": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/installation")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_Installation
{{baseUrl}}/installation
HEADERS

User-Agent
X-Bunq-Client-Authentication
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/installation");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/installation" {:headers {:user-agent ""
                                                                  :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/installation"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/installation"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/installation");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/installation"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/installation HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/installation")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/installation"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/installation")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/installation")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/installation');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/installation',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/installation';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/installation',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/installation")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/installation',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/installation',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/installation');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/installation',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/installation';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/installation"]
                                                       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}}/installation" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/installation",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/installation', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/installation');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/installation');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/installation' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/installation' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/installation", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/installation"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/installation"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/installation")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/installation') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/installation";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".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}}/installation \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/installation \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/installation
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/installation")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_Installation
{{baseUrl}}/installation/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/installation/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/installation/:itemId" {:headers {:user-agent ""
                                                                          :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/installation/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/installation/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/installation/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/installation/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/installation/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/installation/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/installation/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/installation/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/installation/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/installation/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/installation/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/installation/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/installation/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/installation/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/installation/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/installation/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/installation/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/installation/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/installation/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/installation/:itemId"]
                                                       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}}/installation/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/installation/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/installation/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/installation/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/installation/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/installation/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/installation/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/installation/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/installation/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/installation/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/installation/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/installation/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/installation/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".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}}/installation/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/installation/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/installation/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/installation/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_Instance_for_User_MonetaryAccount_PaymentAutoAllocate
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
payment-auto-allocateID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance" {:headers {:user-agent ""
                                                                                                                                                               :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_Instance_for_User_MonetaryAccount_PaymentAutoAllocate
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
payment-auto-allocateID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance/:itemId" {:headers {:user-agent ""
                                                                                                                                                                       :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:payment-auto-allocateID/instance/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_Invoice_for_User
{{baseUrl}}/user/:userID/invoice
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/invoice");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/invoice" {:headers {:user-agent ""
                                                                          :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/invoice"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/invoice"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/invoice");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/invoice"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/invoice HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/invoice")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/invoice"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/invoice")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/invoice")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/invoice');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/invoice',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/invoice';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/invoice',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/invoice")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/invoice',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/invoice',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/invoice');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/invoice',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/invoice';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/invoice"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/invoice" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/invoice",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/invoice', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/invoice');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/invoice');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/invoice' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/invoice' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/invoice", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/invoice"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/invoice"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/invoice")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/invoice') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/invoice";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/invoice \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/invoice \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/invoice
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/invoice")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_Invoice_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice" {:headers {:user-agent ""
                                                                                                               :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/invoice HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/invoice',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/invoice", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/invoice') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_Invoice_for_User
{{baseUrl}}/user/:userID/invoice/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/invoice/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/invoice/:itemId" {:headers {:user-agent ""
                                                                                  :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/invoice/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/invoice/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/invoice/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/invoice/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/invoice/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/invoice/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/invoice/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/invoice/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/invoice/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/invoice/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/invoice/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/invoice/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/invoice/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/invoice/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/invoice/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/invoice/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/invoice/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/invoice/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/invoice/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/invoice/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/invoice/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/invoice/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/invoice/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/invoice/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/invoice/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/invoice/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/invoice/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/invoice/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/invoice/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/invoice/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/invoice/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/invoice/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/invoice/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/invoice/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/invoice/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/invoice/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/invoice/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_Invoice_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice/:itemId" {:headers {:user-agent ""
                                                                                                                       :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/invoice/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/invoice/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/invoice/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/invoice/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/invoice/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_Ip_for_User_CredentialPasswordIp
{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
credential-password-ipID
BODY json

{
  "ip": "",
  "status": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"ip\": \"\",\n  \"status\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip" {:headers {:user-agent ""
                                                                                                                       :x-bunq-client-authentication ""}
                                                                                                             :content-type :json
                                                                                                             :form-params {:ip ""
                                                                                                                           :status ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"ip\": \"\",\n  \"status\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"ip\": \"\",\n  \"status\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"ip\": \"\",\n  \"status\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip"

	payload := strings.NewReader("{\n  \"ip\": \"\",\n  \"status\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/credential-password-ip/:credential-password-ipID/ip HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 30

{
  "ip": "",
  "status": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"ip\": \"\",\n  \"status\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"ip\": \"\",\n  \"status\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"ip\": \"\",\n  \"status\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"ip\": \"\",\n  \"status\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  ip: '',
  status: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {ip: '', status: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"ip":"","status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "ip": "",\n  "status": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"ip\": \"\",\n  \"status\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/credential-password-ip/:credential-password-ipID/ip',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({ip: '', status: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {ip: '', status: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  ip: '',
  status: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {ip: '', status: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"ip":"","status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"ip": @"",
                              @"status": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"ip\": \"\",\n  \"status\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'ip' => '',
    'status' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip', [
  'body' => '{
  "ip": "",
  "status": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'ip' => '',
  'status' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'ip' => '',
  'status' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "ip": "",
  "status": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "ip": "",
  "status": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"ip\": \"\",\n  \"status\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/credential-password-ip/:credential-password-ipID/ip", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip"

payload = {
    "ip": "",
    "status": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip"

payload <- "{\n  \"ip\": \"\",\n  \"status\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"ip\": \"\",\n  \"status\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/credential-password-ip/:credential-password-ipID/ip') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"ip\": \"\",\n  \"status\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip";

    let payload = json!({
        "ip": "",
        "status": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "ip": "",
  "status": ""
}'
echo '{
  "ip": "",
  "status": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "ip": "",\n  "status": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "ip": "",
  "status": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_Ip_for_User_CredentialPasswordIp
{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
credential-password-ipID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip" {:headers {:user-agent ""
                                                                                                                      :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/credential-password-ip/:credential-password-ipID/ip HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/credential-password-ip/:credential-password-ipID/ip',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/credential-password-ip/:credential-password-ipID/ip", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/credential-password-ip/:credential-password-ipID/ip') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_Ip_for_User_CredentialPasswordIp
{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
credential-password-ipID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId" {:headers {:user-agent ""
                                                                                                                              :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_Ip_for_User_CredentialPasswordIp
{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
credential-password-ipID
itemId
BODY json

{
  "ip": "",
  "status": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"ip\": \"\",\n  \"status\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId" {:headers {:user-agent ""
                                                                                                                              :x-bunq-client-authentication ""}
                                                                                                                    :content-type :json
                                                                                                                    :form-params {:ip ""
                                                                                                                                  :status ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"ip\": \"\",\n  \"status\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"ip\": \"\",\n  \"status\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"ip\": \"\",\n  \"status\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId"

	payload := strings.NewReader("{\n  \"ip\": \"\",\n  \"status\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 30

{
  "ip": "",
  "status": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"ip\": \"\",\n  \"status\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"ip\": \"\",\n  \"status\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"ip\": \"\",\n  \"status\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"ip\": \"\",\n  \"status\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  ip: '',
  status: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {ip: '', status: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"ip":"","status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "ip": "",\n  "status": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"ip\": \"\",\n  \"status\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({ip: '', status: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {ip: '', status: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  ip: '',
  status: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {ip: '', status: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"ip":"","status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"ip": @"",
                              @"status": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"ip\": \"\",\n  \"status\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'ip' => '',
    'status' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId', [
  'body' => '{
  "ip": "",
  "status": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'ip' => '',
  'status' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'ip' => '',
  'status' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "ip": "",
  "status": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "ip": "",
  "status": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"ip\": \"\",\n  \"status\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId"

payload = {
    "ip": "",
    "status": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId"

payload <- "{\n  \"ip\": \"\",\n  \"status\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"ip\": \"\",\n  \"status\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"ip\": \"\",\n  \"status\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId";

    let payload = json!({
        "ip": "",
        "status": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "ip": "",
  "status": ""
}'
echo '{
  "ip": "",
  "status": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "ip": "",\n  "status": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "ip": "",
  "status": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/credential-password-ip/:credential-password-ipID/ip/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/legal-name");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/legal-name" {:headers {:user-agent ""
                                                                             :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/legal-name"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/legal-name"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/legal-name");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/legal-name"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/legal-name HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/legal-name")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/legal-name"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/legal-name")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/legal-name")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/legal-name');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/legal-name',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/legal-name';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/legal-name',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/legal-name")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/legal-name',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/legal-name',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/legal-name');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/legal-name',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/legal-name';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/legal-name"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/legal-name" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/legal-name",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/legal-name', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/legal-name');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/legal-name');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/legal-name' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/legal-name' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/legal-name", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/legal-name"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/legal-name"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/legal-name")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/legal-name') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/legal-name";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/legal-name \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/legal-name \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/legal-name
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/legal-name")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_Limit_for_User
{{baseUrl}}/user/:userID/limit
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/limit");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/limit" {:headers {:user-agent ""
                                                                        :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/limit"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/limit"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/limit");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/limit"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/limit HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/limit")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/limit"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/limit")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/limit")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/limit');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/limit',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/limit';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/limit',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/limit")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/limit',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/limit',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/limit');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/limit',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/limit';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/limit"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/limit" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/limit",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/limit', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/limit');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/limit');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/limit' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/limit' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/limit", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/limit"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/limit"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/limit")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/limit') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/limit";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/limit \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/limit \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/limit
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/limit")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_MastercardAction_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action" {:headers {:user-agent ""
                                                                                                                         :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_MastercardAction_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:itemId" {:headers {:user-agent ""
                                                                                                                                 :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_MonetaryAccount_for_User
{{baseUrl}}/user/:userID/monetary-account
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account" {:headers {:user-agent ""
                                                                                   :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_MonetaryAccount_for_User
{{baseUrl}}/user/:userID/monetary-account/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:itemId" {:headers {:user-agent ""
                                                                                           :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_MonetaryAccountBank_for_User
{{baseUrl}}/user/:userID/monetary-account-bank
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
BODY json

{
  "avatar_uuid": "",
  "country_iban": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "display_name": "",
  "reason": "",
  "reason_description": "",
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account-bank");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"avatar_uuid\": \"\",\n  \"country_iban\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"display_name\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account-bank" {:headers {:user-agent ""
                                                                                         :x-bunq-client-authentication ""}
                                                                               :content-type :json
                                                                               :form-params {:avatar_uuid ""
                                                                                             :country_iban ""
                                                                                             :currency ""
                                                                                             :daily_limit {:currency ""
                                                                                                           :value ""}
                                                                                             :description ""
                                                                                             :display_name ""
                                                                                             :reason ""
                                                                                             :reason_description ""
                                                                                             :setting {:color ""
                                                                                                       :default_avatar_status ""
                                                                                                       :icon ""
                                                                                                       :restriction_chat ""
                                                                                                       :sdd_expiration_action ""}
                                                                                             :status ""
                                                                                             :sub_status ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account-bank"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"avatar_uuid\": \"\",\n  \"country_iban\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"display_name\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account-bank"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"avatar_uuid\": \"\",\n  \"country_iban\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"display_name\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account-bank");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"avatar_uuid\": \"\",\n  \"country_iban\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"display_name\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account-bank"

	payload := strings.NewReader("{\n  \"avatar_uuid\": \"\",\n  \"country_iban\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"display_name\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account-bank HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 392

{
  "avatar_uuid": "",
  "country_iban": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "display_name": "",
  "reason": "",
  "reason_description": "",
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account-bank")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"avatar_uuid\": \"\",\n  \"country_iban\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"display_name\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account-bank"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"avatar_uuid\": \"\",\n  \"country_iban\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"display_name\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"avatar_uuid\": \"\",\n  \"country_iban\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"display_name\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account-bank")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account-bank")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"avatar_uuid\": \"\",\n  \"country_iban\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"display_name\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  avatar_uuid: '',
  country_iban: '',
  currency: '',
  daily_limit: {
    currency: '',
    value: ''
  },
  description: '',
  display_name: '',
  reason: '',
  reason_description: '',
  setting: {
    color: '',
    default_avatar_status: '',
    icon: '',
    restriction_chat: '',
    sdd_expiration_action: ''
  },
  status: '',
  sub_status: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account-bank');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account-bank',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    avatar_uuid: '',
    country_iban: '',
    currency: '',
    daily_limit: {currency: '', value: ''},
    description: '',
    display_name: '',
    reason: '',
    reason_description: '',
    setting: {
      color: '',
      default_avatar_status: '',
      icon: '',
      restriction_chat: '',
      sdd_expiration_action: ''
    },
    status: '',
    sub_status: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account-bank';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"avatar_uuid":"","country_iban":"","currency":"","daily_limit":{"currency":"","value":""},"description":"","display_name":"","reason":"","reason_description":"","setting":{"color":"","default_avatar_status":"","icon":"","restriction_chat":"","sdd_expiration_action":""},"status":"","sub_status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account-bank',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "avatar_uuid": "",\n  "country_iban": "",\n  "currency": "",\n  "daily_limit": {\n    "currency": "",\n    "value": ""\n  },\n  "description": "",\n  "display_name": "",\n  "reason": "",\n  "reason_description": "",\n  "setting": {\n    "color": "",\n    "default_avatar_status": "",\n    "icon": "",\n    "restriction_chat": "",\n    "sdd_expiration_action": ""\n  },\n  "status": "",\n  "sub_status": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"avatar_uuid\": \"\",\n  \"country_iban\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"display_name\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account-bank")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account-bank',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  avatar_uuid: '',
  country_iban: '',
  currency: '',
  daily_limit: {currency: '', value: ''},
  description: '',
  display_name: '',
  reason: '',
  reason_description: '',
  setting: {
    color: '',
    default_avatar_status: '',
    icon: '',
    restriction_chat: '',
    sdd_expiration_action: ''
  },
  status: '',
  sub_status: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account-bank',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    avatar_uuid: '',
    country_iban: '',
    currency: '',
    daily_limit: {currency: '', value: ''},
    description: '',
    display_name: '',
    reason: '',
    reason_description: '',
    setting: {
      color: '',
      default_avatar_status: '',
      icon: '',
      restriction_chat: '',
      sdd_expiration_action: ''
    },
    status: '',
    sub_status: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account-bank');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  avatar_uuid: '',
  country_iban: '',
  currency: '',
  daily_limit: {
    currency: '',
    value: ''
  },
  description: '',
  display_name: '',
  reason: '',
  reason_description: '',
  setting: {
    color: '',
    default_avatar_status: '',
    icon: '',
    restriction_chat: '',
    sdd_expiration_action: ''
  },
  status: '',
  sub_status: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account-bank',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    avatar_uuid: '',
    country_iban: '',
    currency: '',
    daily_limit: {currency: '', value: ''},
    description: '',
    display_name: '',
    reason: '',
    reason_description: '',
    setting: {
      color: '',
      default_avatar_status: '',
      icon: '',
      restriction_chat: '',
      sdd_expiration_action: ''
    },
    status: '',
    sub_status: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account-bank';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"avatar_uuid":"","country_iban":"","currency":"","daily_limit":{"currency":"","value":""},"description":"","display_name":"","reason":"","reason_description":"","setting":{"color":"","default_avatar_status":"","icon":"","restriction_chat":"","sdd_expiration_action":""},"status":"","sub_status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"avatar_uuid": @"",
                              @"country_iban": @"",
                              @"currency": @"",
                              @"daily_limit": @{ @"currency": @"", @"value": @"" },
                              @"description": @"",
                              @"display_name": @"",
                              @"reason": @"",
                              @"reason_description": @"",
                              @"setting": @{ @"color": @"", @"default_avatar_status": @"", @"icon": @"", @"restriction_chat": @"", @"sdd_expiration_action": @"" },
                              @"status": @"",
                              @"sub_status": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account-bank"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account-bank" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"avatar_uuid\": \"\",\n  \"country_iban\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"display_name\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account-bank",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'avatar_uuid' => '',
    'country_iban' => '',
    'currency' => '',
    'daily_limit' => [
        'currency' => '',
        'value' => ''
    ],
    'description' => '',
    'display_name' => '',
    'reason' => '',
    'reason_description' => '',
    'setting' => [
        'color' => '',
        'default_avatar_status' => '',
        'icon' => '',
        'restriction_chat' => '',
        'sdd_expiration_action' => ''
    ],
    'status' => '',
    'sub_status' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account-bank', [
  'body' => '{
  "avatar_uuid": "",
  "country_iban": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "display_name": "",
  "reason": "",
  "reason_description": "",
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account-bank');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'avatar_uuid' => '',
  'country_iban' => '',
  'currency' => '',
  'daily_limit' => [
    'currency' => '',
    'value' => ''
  ],
  'description' => '',
  'display_name' => '',
  'reason' => '',
  'reason_description' => '',
  'setting' => [
    'color' => '',
    'default_avatar_status' => '',
    'icon' => '',
    'restriction_chat' => '',
    'sdd_expiration_action' => ''
  ],
  'status' => '',
  'sub_status' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'avatar_uuid' => '',
  'country_iban' => '',
  'currency' => '',
  'daily_limit' => [
    'currency' => '',
    'value' => ''
  ],
  'description' => '',
  'display_name' => '',
  'reason' => '',
  'reason_description' => '',
  'setting' => [
    'color' => '',
    'default_avatar_status' => '',
    'icon' => '',
    'restriction_chat' => '',
    'sdd_expiration_action' => ''
  ],
  'status' => '',
  'sub_status' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account-bank');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account-bank' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "avatar_uuid": "",
  "country_iban": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "display_name": "",
  "reason": "",
  "reason_description": "",
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account-bank' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "avatar_uuid": "",
  "country_iban": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "display_name": "",
  "reason": "",
  "reason_description": "",
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"avatar_uuid\": \"\",\n  \"country_iban\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"display_name\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account-bank", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account-bank"

payload = {
    "avatar_uuid": "",
    "country_iban": "",
    "currency": "",
    "daily_limit": {
        "currency": "",
        "value": ""
    },
    "description": "",
    "display_name": "",
    "reason": "",
    "reason_description": "",
    "setting": {
        "color": "",
        "default_avatar_status": "",
        "icon": "",
        "restriction_chat": "",
        "sdd_expiration_action": ""
    },
    "status": "",
    "sub_status": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account-bank"

payload <- "{\n  \"avatar_uuid\": \"\",\n  \"country_iban\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"display_name\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account-bank")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"avatar_uuid\": \"\",\n  \"country_iban\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"display_name\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account-bank') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"avatar_uuid\": \"\",\n  \"country_iban\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"display_name\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account-bank";

    let payload = json!({
        "avatar_uuid": "",
        "country_iban": "",
        "currency": "",
        "daily_limit": json!({
            "currency": "",
            "value": ""
        }),
        "description": "",
        "display_name": "",
        "reason": "",
        "reason_description": "",
        "setting": json!({
            "color": "",
            "default_avatar_status": "",
            "icon": "",
            "restriction_chat": "",
            "sdd_expiration_action": ""
        }),
        "status": "",
        "sub_status": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account-bank \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "avatar_uuid": "",
  "country_iban": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "display_name": "",
  "reason": "",
  "reason_description": "",
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}'
echo '{
  "avatar_uuid": "",
  "country_iban": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "display_name": "",
  "reason": "",
  "reason_description": "",
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account-bank \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "avatar_uuid": "",\n  "country_iban": "",\n  "currency": "",\n  "daily_limit": {\n    "currency": "",\n    "value": ""\n  },\n  "description": "",\n  "display_name": "",\n  "reason": "",\n  "reason_description": "",\n  "setting": {\n    "color": "",\n    "default_avatar_status": "",\n    "icon": "",\n    "restriction_chat": "",\n    "sdd_expiration_action": ""\n  },\n  "status": "",\n  "sub_status": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account-bank
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "avatar_uuid": "",
  "country_iban": "",
  "currency": "",
  "daily_limit": [
    "currency": "",
    "value": ""
  ],
  "description": "",
  "display_name": "",
  "reason": "",
  "reason_description": "",
  "setting": [
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  ],
  "status": "",
  "sub_status": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account-bank")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_MonetaryAccountBank_for_User
{{baseUrl}}/user/:userID/monetary-account-bank
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account-bank");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account-bank" {:headers {:user-agent ""
                                                                                        :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account-bank"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account-bank"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account-bank");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account-bank"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account-bank HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account-bank")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account-bank"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account-bank")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account-bank")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account-bank');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account-bank',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account-bank';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account-bank',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account-bank")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account-bank',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account-bank',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account-bank');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account-bank',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account-bank';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account-bank"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account-bank" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account-bank",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account-bank', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account-bank');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account-bank');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account-bank' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account-bank' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account-bank", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account-bank"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account-bank"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account-bank")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account-bank') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account-bank";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account-bank \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account-bank \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account-bank
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account-bank")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_MonetaryAccountBank_for_User
{{baseUrl}}/user/:userID/monetary-account-bank/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account-bank/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account-bank/:itemId" {:headers {:user-agent ""
                                                                                                :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account-bank/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account-bank/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account-bank/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account-bank/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account-bank/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account-bank/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account-bank/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account-bank/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account-bank/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account-bank/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account-bank/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account-bank/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account-bank/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account-bank/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account-bank/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account-bank/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account-bank/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account-bank/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account-bank/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account-bank/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account-bank/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account-bank/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account-bank/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account-bank/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account-bank/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account-bank/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account-bank/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account-bank/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account-bank/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account-bank/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account-bank/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account-bank/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account-bank/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account-bank/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account-bank/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account-bank/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account-bank/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_MonetaryAccountBank_for_User
{{baseUrl}}/user/:userID/monetary-account-bank/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
BODY json

{
  "avatar_uuid": "",
  "country_iban": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "display_name": "",
  "reason": "",
  "reason_description": "",
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account-bank/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"avatar_uuid\": \"\",\n  \"country_iban\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"display_name\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account-bank/:itemId" {:headers {:user-agent ""
                                                                                                :x-bunq-client-authentication ""}
                                                                                      :content-type :json
                                                                                      :form-params {:avatar_uuid ""
                                                                                                    :country_iban ""
                                                                                                    :currency ""
                                                                                                    :daily_limit {:currency ""
                                                                                                                  :value ""}
                                                                                                    :description ""
                                                                                                    :display_name ""
                                                                                                    :reason ""
                                                                                                    :reason_description ""
                                                                                                    :setting {:color ""
                                                                                                              :default_avatar_status ""
                                                                                                              :icon ""
                                                                                                              :restriction_chat ""
                                                                                                              :sdd_expiration_action ""}
                                                                                                    :status ""
                                                                                                    :sub_status ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account-bank/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"avatar_uuid\": \"\",\n  \"country_iban\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"display_name\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account-bank/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"avatar_uuid\": \"\",\n  \"country_iban\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"display_name\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account-bank/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"avatar_uuid\": \"\",\n  \"country_iban\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"display_name\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account-bank/:itemId"

	payload := strings.NewReader("{\n  \"avatar_uuid\": \"\",\n  \"country_iban\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"display_name\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account-bank/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 392

{
  "avatar_uuid": "",
  "country_iban": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "display_name": "",
  "reason": "",
  "reason_description": "",
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account-bank/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"avatar_uuid\": \"\",\n  \"country_iban\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"display_name\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account-bank/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"avatar_uuid\": \"\",\n  \"country_iban\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"display_name\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"avatar_uuid\": \"\",\n  \"country_iban\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"display_name\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account-bank/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account-bank/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"avatar_uuid\": \"\",\n  \"country_iban\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"display_name\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  avatar_uuid: '',
  country_iban: '',
  currency: '',
  daily_limit: {
    currency: '',
    value: ''
  },
  description: '',
  display_name: '',
  reason: '',
  reason_description: '',
  setting: {
    color: '',
    default_avatar_status: '',
    icon: '',
    restriction_chat: '',
    sdd_expiration_action: ''
  },
  status: '',
  sub_status: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account-bank/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account-bank/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    avatar_uuid: '',
    country_iban: '',
    currency: '',
    daily_limit: {currency: '', value: ''},
    description: '',
    display_name: '',
    reason: '',
    reason_description: '',
    setting: {
      color: '',
      default_avatar_status: '',
      icon: '',
      restriction_chat: '',
      sdd_expiration_action: ''
    },
    status: '',
    sub_status: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account-bank/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"avatar_uuid":"","country_iban":"","currency":"","daily_limit":{"currency":"","value":""},"description":"","display_name":"","reason":"","reason_description":"","setting":{"color":"","default_avatar_status":"","icon":"","restriction_chat":"","sdd_expiration_action":""},"status":"","sub_status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account-bank/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "avatar_uuid": "",\n  "country_iban": "",\n  "currency": "",\n  "daily_limit": {\n    "currency": "",\n    "value": ""\n  },\n  "description": "",\n  "display_name": "",\n  "reason": "",\n  "reason_description": "",\n  "setting": {\n    "color": "",\n    "default_avatar_status": "",\n    "icon": "",\n    "restriction_chat": "",\n    "sdd_expiration_action": ""\n  },\n  "status": "",\n  "sub_status": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"avatar_uuid\": \"\",\n  \"country_iban\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"display_name\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account-bank/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account-bank/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  avatar_uuid: '',
  country_iban: '',
  currency: '',
  daily_limit: {currency: '', value: ''},
  description: '',
  display_name: '',
  reason: '',
  reason_description: '',
  setting: {
    color: '',
    default_avatar_status: '',
    icon: '',
    restriction_chat: '',
    sdd_expiration_action: ''
  },
  status: '',
  sub_status: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account-bank/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    avatar_uuid: '',
    country_iban: '',
    currency: '',
    daily_limit: {currency: '', value: ''},
    description: '',
    display_name: '',
    reason: '',
    reason_description: '',
    setting: {
      color: '',
      default_avatar_status: '',
      icon: '',
      restriction_chat: '',
      sdd_expiration_action: ''
    },
    status: '',
    sub_status: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account-bank/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  avatar_uuid: '',
  country_iban: '',
  currency: '',
  daily_limit: {
    currency: '',
    value: ''
  },
  description: '',
  display_name: '',
  reason: '',
  reason_description: '',
  setting: {
    color: '',
    default_avatar_status: '',
    icon: '',
    restriction_chat: '',
    sdd_expiration_action: ''
  },
  status: '',
  sub_status: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account-bank/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    avatar_uuid: '',
    country_iban: '',
    currency: '',
    daily_limit: {currency: '', value: ''},
    description: '',
    display_name: '',
    reason: '',
    reason_description: '',
    setting: {
      color: '',
      default_avatar_status: '',
      icon: '',
      restriction_chat: '',
      sdd_expiration_action: ''
    },
    status: '',
    sub_status: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account-bank/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"avatar_uuid":"","country_iban":"","currency":"","daily_limit":{"currency":"","value":""},"description":"","display_name":"","reason":"","reason_description":"","setting":{"color":"","default_avatar_status":"","icon":"","restriction_chat":"","sdd_expiration_action":""},"status":"","sub_status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"avatar_uuid": @"",
                              @"country_iban": @"",
                              @"currency": @"",
                              @"daily_limit": @{ @"currency": @"", @"value": @"" },
                              @"description": @"",
                              @"display_name": @"",
                              @"reason": @"",
                              @"reason_description": @"",
                              @"setting": @{ @"color": @"", @"default_avatar_status": @"", @"icon": @"", @"restriction_chat": @"", @"sdd_expiration_action": @"" },
                              @"status": @"",
                              @"sub_status": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account-bank/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account-bank/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"avatar_uuid\": \"\",\n  \"country_iban\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"display_name\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account-bank/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'avatar_uuid' => '',
    'country_iban' => '',
    'currency' => '',
    'daily_limit' => [
        'currency' => '',
        'value' => ''
    ],
    'description' => '',
    'display_name' => '',
    'reason' => '',
    'reason_description' => '',
    'setting' => [
        'color' => '',
        'default_avatar_status' => '',
        'icon' => '',
        'restriction_chat' => '',
        'sdd_expiration_action' => ''
    ],
    'status' => '',
    'sub_status' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account-bank/:itemId', [
  'body' => '{
  "avatar_uuid": "",
  "country_iban": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "display_name": "",
  "reason": "",
  "reason_description": "",
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account-bank/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'avatar_uuid' => '',
  'country_iban' => '',
  'currency' => '',
  'daily_limit' => [
    'currency' => '',
    'value' => ''
  ],
  'description' => '',
  'display_name' => '',
  'reason' => '',
  'reason_description' => '',
  'setting' => [
    'color' => '',
    'default_avatar_status' => '',
    'icon' => '',
    'restriction_chat' => '',
    'sdd_expiration_action' => ''
  ],
  'status' => '',
  'sub_status' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'avatar_uuid' => '',
  'country_iban' => '',
  'currency' => '',
  'daily_limit' => [
    'currency' => '',
    'value' => ''
  ],
  'description' => '',
  'display_name' => '',
  'reason' => '',
  'reason_description' => '',
  'setting' => [
    'color' => '',
    'default_avatar_status' => '',
    'icon' => '',
    'restriction_chat' => '',
    'sdd_expiration_action' => ''
  ],
  'status' => '',
  'sub_status' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account-bank/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account-bank/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "avatar_uuid": "",
  "country_iban": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "display_name": "",
  "reason": "",
  "reason_description": "",
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account-bank/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "avatar_uuid": "",
  "country_iban": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "display_name": "",
  "reason": "",
  "reason_description": "",
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"avatar_uuid\": \"\",\n  \"country_iban\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"display_name\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account-bank/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account-bank/:itemId"

payload = {
    "avatar_uuid": "",
    "country_iban": "",
    "currency": "",
    "daily_limit": {
        "currency": "",
        "value": ""
    },
    "description": "",
    "display_name": "",
    "reason": "",
    "reason_description": "",
    "setting": {
        "color": "",
        "default_avatar_status": "",
        "icon": "",
        "restriction_chat": "",
        "sdd_expiration_action": ""
    },
    "status": "",
    "sub_status": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account-bank/:itemId"

payload <- "{\n  \"avatar_uuid\": \"\",\n  \"country_iban\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"display_name\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account-bank/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"avatar_uuid\": \"\",\n  \"country_iban\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"display_name\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account-bank/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"avatar_uuid\": \"\",\n  \"country_iban\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"display_name\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account-bank/:itemId";

    let payload = json!({
        "avatar_uuid": "",
        "country_iban": "",
        "currency": "",
        "daily_limit": json!({
            "currency": "",
            "value": ""
        }),
        "description": "",
        "display_name": "",
        "reason": "",
        "reason_description": "",
        "setting": json!({
            "color": "",
            "default_avatar_status": "",
            "icon": "",
            "restriction_chat": "",
            "sdd_expiration_action": ""
        }),
        "status": "",
        "sub_status": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account-bank/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "avatar_uuid": "",
  "country_iban": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "display_name": "",
  "reason": "",
  "reason_description": "",
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}'
echo '{
  "avatar_uuid": "",
  "country_iban": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "display_name": "",
  "reason": "",
  "reason_description": "",
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account-bank/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "avatar_uuid": "",\n  "country_iban": "",\n  "currency": "",\n  "daily_limit": {\n    "currency": "",\n    "value": ""\n  },\n  "description": "",\n  "display_name": "",\n  "reason": "",\n  "reason_description": "",\n  "setting": {\n    "color": "",\n    "default_avatar_status": "",\n    "icon": "",\n    "restriction_chat": "",\n    "sdd_expiration_action": ""\n  },\n  "status": "",\n  "sub_status": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account-bank/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "avatar_uuid": "",
  "country_iban": "",
  "currency": "",
  "daily_limit": [
    "currency": "",
    "value": ""
  ],
  "description": "",
  "display_name": "",
  "reason": "",
  "reason_description": "",
  "setting": [
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  ],
  "status": "",
  "sub_status": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account-bank/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_MonetaryAccountExternal_for_User
{{baseUrl}}/user/:userID/monetary-account-external
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account-external");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account-external" {:headers {:user-agent ""
                                                                                            :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account-external"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account-external"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account-external");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account-external"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account-external HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account-external")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account-external"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account-external")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account-external")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account-external');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account-external',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account-external';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account-external',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account-external")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account-external',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account-external',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account-external');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account-external',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account-external';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account-external"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account-external" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account-external",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account-external', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account-external');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account-external');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account-external' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account-external' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account-external", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account-external"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account-external"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account-external")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account-external') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account-external";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account-external \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account-external \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account-external
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account-external")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_MonetaryAccountExternal_for_User
{{baseUrl}}/user/:userID/monetary-account-external/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account-external/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account-external/:itemId" {:headers {:user-agent ""
                                                                                                    :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account-external/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account-external/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account-external/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account-external/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account-external/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account-external/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account-external/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account-external/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account-external/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account-external/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account-external/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account-external/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account-external/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account-external/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account-external/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account-external/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account-external/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account-external/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account-external/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account-external/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account-external/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account-external/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account-external/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account-external/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account-external/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account-external/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account-external/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account-external/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account-external/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account-external/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account-external/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account-external/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account-external/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account-external/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account-external/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account-external/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account-external/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_MonetaryAccountJoint_for_User
{{baseUrl}}/user/:userID/monetary-account-joint
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
BODY json

{
  "alias": [
    {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    }
  ],
  "all_co_owner": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "status": ""
    }
  ],
  "avatar_uuid": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "overdraft_limit": {},
  "reason": "",
  "reason_description": "",
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account-joint");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"overdraft_limit\": {},\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account-joint" {:headers {:user-agent ""
                                                                                          :x-bunq-client-authentication ""}
                                                                                :content-type :json
                                                                                :form-params {:alias [{:name ""
                                                                                                       :service ""
                                                                                                       :type ""
                                                                                                       :value ""}]
                                                                                              :all_co_owner [{:alias {:avatar {:anchor_uuid ""
                                                                                                                               :image [{:attachment_public_uuid ""
                                                                                                                                        :content_type ""
                                                                                                                                        :height 0
                                                                                                                                        :width 0}]
                                                                                                                               :style ""
                                                                                                                               :uuid ""}
                                                                                                                      :country ""
                                                                                                                      :display_name ""
                                                                                                                      :public_nick_name ""
                                                                                                                      :uuid ""}
                                                                                                              :status ""}]
                                                                                              :avatar_uuid ""
                                                                                              :currency ""
                                                                                              :daily_limit {:currency ""
                                                                                                            :value ""}
                                                                                              :description ""
                                                                                              :overdraft_limit {}
                                                                                              :reason ""
                                                                                              :reason_description ""
                                                                                              :setting {:color ""
                                                                                                        :default_avatar_status ""
                                                                                                        :icon ""
                                                                                                        :restriction_chat ""
                                                                                                        :sdd_expiration_action ""}
                                                                                              :status ""
                                                                                              :sub_status ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account-joint"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"overdraft_limit\": {},\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account-joint"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"overdraft_limit\": {},\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account-joint");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"overdraft_limit\": {},\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account-joint"

	payload := strings.NewReader("{\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"overdraft_limit\": {},\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account-joint HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 958

{
  "alias": [
    {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    }
  ],
  "all_co_owner": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "status": ""
    }
  ],
  "avatar_uuid": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "overdraft_limit": {},
  "reason": "",
  "reason_description": "",
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account-joint")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"overdraft_limit\": {},\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account-joint"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"overdraft_limit\": {},\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"overdraft_limit\": {},\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account-joint")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account-joint")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"overdraft_limit\": {},\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  alias: [
    {
      name: '',
      service: '',
      type: '',
      value: ''
    }
  ],
  all_co_owner: [
    {
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [
            {
              attachment_public_uuid: '',
              content_type: '',
              height: 0,
              width: 0
            }
          ],
          style: '',
          uuid: ''
        },
        country: '',
        display_name: '',
        public_nick_name: '',
        uuid: ''
      },
      status: ''
    }
  ],
  avatar_uuid: '',
  currency: '',
  daily_limit: {
    currency: '',
    value: ''
  },
  description: '',
  overdraft_limit: {},
  reason: '',
  reason_description: '',
  setting: {
    color: '',
    default_avatar_status: '',
    icon: '',
    restriction_chat: '',
    sdd_expiration_action: ''
  },
  status: '',
  sub_status: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account-joint');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account-joint',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    alias: [{name: '', service: '', type: '', value: ''}],
    all_co_owner: [
      {
        alias: {
          avatar: {
            anchor_uuid: '',
            image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
            style: '',
            uuid: ''
          },
          country: '',
          display_name: '',
          public_nick_name: '',
          uuid: ''
        },
        status: ''
      }
    ],
    avatar_uuid: '',
    currency: '',
    daily_limit: {currency: '', value: ''},
    description: '',
    overdraft_limit: {},
    reason: '',
    reason_description: '',
    setting: {
      color: '',
      default_avatar_status: '',
      icon: '',
      restriction_chat: '',
      sdd_expiration_action: ''
    },
    status: '',
    sub_status: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account-joint';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"alias":[{"name":"","service":"","type":"","value":""}],"all_co_owner":[{"alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"country":"","display_name":"","public_nick_name":"","uuid":""},"status":""}],"avatar_uuid":"","currency":"","daily_limit":{"currency":"","value":""},"description":"","overdraft_limit":{},"reason":"","reason_description":"","setting":{"color":"","default_avatar_status":"","icon":"","restriction_chat":"","sdd_expiration_action":""},"status":"","sub_status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account-joint',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "alias": [\n    {\n      "name": "",\n      "service": "",\n      "type": "",\n      "value": ""\n    }\n  ],\n  "all_co_owner": [\n    {\n      "alias": {\n        "avatar": {\n          "anchor_uuid": "",\n          "image": [\n            {\n              "attachment_public_uuid": "",\n              "content_type": "",\n              "height": 0,\n              "width": 0\n            }\n          ],\n          "style": "",\n          "uuid": ""\n        },\n        "country": "",\n        "display_name": "",\n        "public_nick_name": "",\n        "uuid": ""\n      },\n      "status": ""\n    }\n  ],\n  "avatar_uuid": "",\n  "currency": "",\n  "daily_limit": {\n    "currency": "",\n    "value": ""\n  },\n  "description": "",\n  "overdraft_limit": {},\n  "reason": "",\n  "reason_description": "",\n  "setting": {\n    "color": "",\n    "default_avatar_status": "",\n    "icon": "",\n    "restriction_chat": "",\n    "sdd_expiration_action": ""\n  },\n  "status": "",\n  "sub_status": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"overdraft_limit\": {},\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account-joint")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account-joint',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  alias: [{name: '', service: '', type: '', value: ''}],
  all_co_owner: [
    {
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
          style: '',
          uuid: ''
        },
        country: '',
        display_name: '',
        public_nick_name: '',
        uuid: ''
      },
      status: ''
    }
  ],
  avatar_uuid: '',
  currency: '',
  daily_limit: {currency: '', value: ''},
  description: '',
  overdraft_limit: {},
  reason: '',
  reason_description: '',
  setting: {
    color: '',
    default_avatar_status: '',
    icon: '',
    restriction_chat: '',
    sdd_expiration_action: ''
  },
  status: '',
  sub_status: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account-joint',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    alias: [{name: '', service: '', type: '', value: ''}],
    all_co_owner: [
      {
        alias: {
          avatar: {
            anchor_uuid: '',
            image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
            style: '',
            uuid: ''
          },
          country: '',
          display_name: '',
          public_nick_name: '',
          uuid: ''
        },
        status: ''
      }
    ],
    avatar_uuid: '',
    currency: '',
    daily_limit: {currency: '', value: ''},
    description: '',
    overdraft_limit: {},
    reason: '',
    reason_description: '',
    setting: {
      color: '',
      default_avatar_status: '',
      icon: '',
      restriction_chat: '',
      sdd_expiration_action: ''
    },
    status: '',
    sub_status: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account-joint');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  alias: [
    {
      name: '',
      service: '',
      type: '',
      value: ''
    }
  ],
  all_co_owner: [
    {
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [
            {
              attachment_public_uuid: '',
              content_type: '',
              height: 0,
              width: 0
            }
          ],
          style: '',
          uuid: ''
        },
        country: '',
        display_name: '',
        public_nick_name: '',
        uuid: ''
      },
      status: ''
    }
  ],
  avatar_uuid: '',
  currency: '',
  daily_limit: {
    currency: '',
    value: ''
  },
  description: '',
  overdraft_limit: {},
  reason: '',
  reason_description: '',
  setting: {
    color: '',
    default_avatar_status: '',
    icon: '',
    restriction_chat: '',
    sdd_expiration_action: ''
  },
  status: '',
  sub_status: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account-joint',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    alias: [{name: '', service: '', type: '', value: ''}],
    all_co_owner: [
      {
        alias: {
          avatar: {
            anchor_uuid: '',
            image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
            style: '',
            uuid: ''
          },
          country: '',
          display_name: '',
          public_nick_name: '',
          uuid: ''
        },
        status: ''
      }
    ],
    avatar_uuid: '',
    currency: '',
    daily_limit: {currency: '', value: ''},
    description: '',
    overdraft_limit: {},
    reason: '',
    reason_description: '',
    setting: {
      color: '',
      default_avatar_status: '',
      icon: '',
      restriction_chat: '',
      sdd_expiration_action: ''
    },
    status: '',
    sub_status: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account-joint';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"alias":[{"name":"","service":"","type":"","value":""}],"all_co_owner":[{"alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"country":"","display_name":"","public_nick_name":"","uuid":""},"status":""}],"avatar_uuid":"","currency":"","daily_limit":{"currency":"","value":""},"description":"","overdraft_limit":{},"reason":"","reason_description":"","setting":{"color":"","default_avatar_status":"","icon":"","restriction_chat":"","sdd_expiration_action":""},"status":"","sub_status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"alias": @[ @{ @"name": @"", @"service": @"", @"type": @"", @"value": @"" } ],
                              @"all_co_owner": @[ @{ @"alias": @{ @"avatar": @{ @"anchor_uuid": @"", @"image": @[ @{ @"attachment_public_uuid": @"", @"content_type": @"", @"height": @0, @"width": @0 } ], @"style": @"", @"uuid": @"" }, @"country": @"", @"display_name": @"", @"public_nick_name": @"", @"uuid": @"" }, @"status": @"" } ],
                              @"avatar_uuid": @"",
                              @"currency": @"",
                              @"daily_limit": @{ @"currency": @"", @"value": @"" },
                              @"description": @"",
                              @"overdraft_limit": @{  },
                              @"reason": @"",
                              @"reason_description": @"",
                              @"setting": @{ @"color": @"", @"default_avatar_status": @"", @"icon": @"", @"restriction_chat": @"", @"sdd_expiration_action": @"" },
                              @"status": @"",
                              @"sub_status": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account-joint"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account-joint" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"overdraft_limit\": {},\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account-joint",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'alias' => [
        [
                'name' => '',
                'service' => '',
                'type' => '',
                'value' => ''
        ]
    ],
    'all_co_owner' => [
        [
                'alias' => [
                                'avatar' => [
                                                                'anchor_uuid' => '',
                                                                'image' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'attachment_public_uuid' => '',
                                                                                                                                                                                                                                                                'content_type' => '',
                                                                                                                                                                                                                                                                'height' => 0,
                                                                                                                                                                                                                                                                'width' => 0
                                                                                                                                ]
                                                                ],
                                                                'style' => '',
                                                                'uuid' => ''
                                ],
                                'country' => '',
                                'display_name' => '',
                                'public_nick_name' => '',
                                'uuid' => ''
                ],
                'status' => ''
        ]
    ],
    'avatar_uuid' => '',
    'currency' => '',
    'daily_limit' => [
        'currency' => '',
        'value' => ''
    ],
    'description' => '',
    'overdraft_limit' => [
        
    ],
    'reason' => '',
    'reason_description' => '',
    'setting' => [
        'color' => '',
        'default_avatar_status' => '',
        'icon' => '',
        'restriction_chat' => '',
        'sdd_expiration_action' => ''
    ],
    'status' => '',
    'sub_status' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account-joint', [
  'body' => '{
  "alias": [
    {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    }
  ],
  "all_co_owner": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "status": ""
    }
  ],
  "avatar_uuid": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "overdraft_limit": {},
  "reason": "",
  "reason_description": "",
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account-joint');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'alias' => [
    [
        'name' => '',
        'service' => '',
        'type' => '',
        'value' => ''
    ]
  ],
  'all_co_owner' => [
    [
        'alias' => [
                'avatar' => [
                                'anchor_uuid' => '',
                                'image' => [
                                                                [
                                                                                                                                'attachment_public_uuid' => '',
                                                                                                                                'content_type' => '',
                                                                                                                                'height' => 0,
                                                                                                                                'width' => 0
                                                                ]
                                ],
                                'style' => '',
                                'uuid' => ''
                ],
                'country' => '',
                'display_name' => '',
                'public_nick_name' => '',
                'uuid' => ''
        ],
        'status' => ''
    ]
  ],
  'avatar_uuid' => '',
  'currency' => '',
  'daily_limit' => [
    'currency' => '',
    'value' => ''
  ],
  'description' => '',
  'overdraft_limit' => [
    
  ],
  'reason' => '',
  'reason_description' => '',
  'setting' => [
    'color' => '',
    'default_avatar_status' => '',
    'icon' => '',
    'restriction_chat' => '',
    'sdd_expiration_action' => ''
  ],
  'status' => '',
  'sub_status' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'alias' => [
    [
        'name' => '',
        'service' => '',
        'type' => '',
        'value' => ''
    ]
  ],
  'all_co_owner' => [
    [
        'alias' => [
                'avatar' => [
                                'anchor_uuid' => '',
                                'image' => [
                                                                [
                                                                                                                                'attachment_public_uuid' => '',
                                                                                                                                'content_type' => '',
                                                                                                                                'height' => 0,
                                                                                                                                'width' => 0
                                                                ]
                                ],
                                'style' => '',
                                'uuid' => ''
                ],
                'country' => '',
                'display_name' => '',
                'public_nick_name' => '',
                'uuid' => ''
        ],
        'status' => ''
    ]
  ],
  'avatar_uuid' => '',
  'currency' => '',
  'daily_limit' => [
    'currency' => '',
    'value' => ''
  ],
  'description' => '',
  'overdraft_limit' => [
    
  ],
  'reason' => '',
  'reason_description' => '',
  'setting' => [
    'color' => '',
    'default_avatar_status' => '',
    'icon' => '',
    'restriction_chat' => '',
    'sdd_expiration_action' => ''
  ],
  'status' => '',
  'sub_status' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account-joint');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account-joint' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "alias": [
    {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    }
  ],
  "all_co_owner": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "status": ""
    }
  ],
  "avatar_uuid": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "overdraft_limit": {},
  "reason": "",
  "reason_description": "",
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account-joint' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "alias": [
    {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    }
  ],
  "all_co_owner": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "status": ""
    }
  ],
  "avatar_uuid": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "overdraft_limit": {},
  "reason": "",
  "reason_description": "",
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"overdraft_limit\": {},\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account-joint", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account-joint"

payload = {
    "alias": [
        {
            "name": "",
            "service": "",
            "type": "",
            "value": ""
        }
    ],
    "all_co_owner": [
        {
            "alias": {
                "avatar": {
                    "anchor_uuid": "",
                    "image": [
                        {
                            "attachment_public_uuid": "",
                            "content_type": "",
                            "height": 0,
                            "width": 0
                        }
                    ],
                    "style": "",
                    "uuid": ""
                },
                "country": "",
                "display_name": "",
                "public_nick_name": "",
                "uuid": ""
            },
            "status": ""
        }
    ],
    "avatar_uuid": "",
    "currency": "",
    "daily_limit": {
        "currency": "",
        "value": ""
    },
    "description": "",
    "overdraft_limit": {},
    "reason": "",
    "reason_description": "",
    "setting": {
        "color": "",
        "default_avatar_status": "",
        "icon": "",
        "restriction_chat": "",
        "sdd_expiration_action": ""
    },
    "status": "",
    "sub_status": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account-joint"

payload <- "{\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"overdraft_limit\": {},\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account-joint")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"overdraft_limit\": {},\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account-joint') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"overdraft_limit\": {},\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account-joint";

    let payload = json!({
        "alias": (
            json!({
                "name": "",
                "service": "",
                "type": "",
                "value": ""
            })
        ),
        "all_co_owner": (
            json!({
                "alias": json!({
                    "avatar": json!({
                        "anchor_uuid": "",
                        "image": (
                            json!({
                                "attachment_public_uuid": "",
                                "content_type": "",
                                "height": 0,
                                "width": 0
                            })
                        ),
                        "style": "",
                        "uuid": ""
                    }),
                    "country": "",
                    "display_name": "",
                    "public_nick_name": "",
                    "uuid": ""
                }),
                "status": ""
            })
        ),
        "avatar_uuid": "",
        "currency": "",
        "daily_limit": json!({
            "currency": "",
            "value": ""
        }),
        "description": "",
        "overdraft_limit": json!({}),
        "reason": "",
        "reason_description": "",
        "setting": json!({
            "color": "",
            "default_avatar_status": "",
            "icon": "",
            "restriction_chat": "",
            "sdd_expiration_action": ""
        }),
        "status": "",
        "sub_status": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account-joint \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "alias": [
    {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    }
  ],
  "all_co_owner": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "status": ""
    }
  ],
  "avatar_uuid": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "overdraft_limit": {},
  "reason": "",
  "reason_description": "",
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}'
echo '{
  "alias": [
    {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    }
  ],
  "all_co_owner": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "status": ""
    }
  ],
  "avatar_uuid": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "overdraft_limit": {},
  "reason": "",
  "reason_description": "",
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account-joint \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "alias": [\n    {\n      "name": "",\n      "service": "",\n      "type": "",\n      "value": ""\n    }\n  ],\n  "all_co_owner": [\n    {\n      "alias": {\n        "avatar": {\n          "anchor_uuid": "",\n          "image": [\n            {\n              "attachment_public_uuid": "",\n              "content_type": "",\n              "height": 0,\n              "width": 0\n            }\n          ],\n          "style": "",\n          "uuid": ""\n        },\n        "country": "",\n        "display_name": "",\n        "public_nick_name": "",\n        "uuid": ""\n      },\n      "status": ""\n    }\n  ],\n  "avatar_uuid": "",\n  "currency": "",\n  "daily_limit": {\n    "currency": "",\n    "value": ""\n  },\n  "description": "",\n  "overdraft_limit": {},\n  "reason": "",\n  "reason_description": "",\n  "setting": {\n    "color": "",\n    "default_avatar_status": "",\n    "icon": "",\n    "restriction_chat": "",\n    "sdd_expiration_action": ""\n  },\n  "status": "",\n  "sub_status": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account-joint
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "alias": [
    [
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    ]
  ],
  "all_co_owner": [
    [
      "alias": [
        "avatar": [
          "anchor_uuid": "",
          "image": [
            [
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            ]
          ],
          "style": "",
          "uuid": ""
        ],
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      ],
      "status": ""
    ]
  ],
  "avatar_uuid": "",
  "currency": "",
  "daily_limit": [
    "currency": "",
    "value": ""
  ],
  "description": "",
  "overdraft_limit": [],
  "reason": "",
  "reason_description": "",
  "setting": [
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  ],
  "status": "",
  "sub_status": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account-joint")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_MonetaryAccountJoint_for_User
{{baseUrl}}/user/:userID/monetary-account-joint
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account-joint");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account-joint" {:headers {:user-agent ""
                                                                                         :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account-joint"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account-joint"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account-joint");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account-joint"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account-joint HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account-joint")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account-joint"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account-joint")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account-joint")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account-joint');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account-joint',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account-joint';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account-joint',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account-joint")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account-joint',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account-joint',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account-joint');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account-joint',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account-joint';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account-joint"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account-joint" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account-joint",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account-joint', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account-joint');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account-joint');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account-joint' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account-joint' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account-joint", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account-joint"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account-joint"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account-joint")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account-joint') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account-joint";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account-joint \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account-joint \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account-joint
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account-joint")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_MonetaryAccountJoint_for_User
{{baseUrl}}/user/:userID/monetary-account-joint/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account-joint/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account-joint/:itemId" {:headers {:user-agent ""
                                                                                                 :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account-joint/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account-joint/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account-joint/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account-joint/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account-joint/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account-joint/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account-joint/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account-joint/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account-joint/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account-joint/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account-joint/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account-joint/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account-joint/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account-joint/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account-joint/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account-joint/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account-joint/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account-joint/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account-joint/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account-joint/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account-joint/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account-joint/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account-joint/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account-joint/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account-joint/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account-joint/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account-joint/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account-joint/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account-joint/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account-joint/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account-joint/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account-joint/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account-joint/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account-joint/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account-joint/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account-joint/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account-joint/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_MonetaryAccountJoint_for_User
{{baseUrl}}/user/:userID/monetary-account-joint/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
BODY json

{
  "alias": [
    {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    }
  ],
  "all_co_owner": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "status": ""
    }
  ],
  "avatar_uuid": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "overdraft_limit": {},
  "reason": "",
  "reason_description": "",
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account-joint/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"overdraft_limit\": {},\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account-joint/:itemId" {:headers {:user-agent ""
                                                                                                 :x-bunq-client-authentication ""}
                                                                                       :content-type :json
                                                                                       :form-params {:alias [{:name ""
                                                                                                              :service ""
                                                                                                              :type ""
                                                                                                              :value ""}]
                                                                                                     :all_co_owner [{:alias {:avatar {:anchor_uuid ""
                                                                                                                                      :image [{:attachment_public_uuid ""
                                                                                                                                               :content_type ""
                                                                                                                                               :height 0
                                                                                                                                               :width 0}]
                                                                                                                                      :style ""
                                                                                                                                      :uuid ""}
                                                                                                                             :country ""
                                                                                                                             :display_name ""
                                                                                                                             :public_nick_name ""
                                                                                                                             :uuid ""}
                                                                                                                     :status ""}]
                                                                                                     :avatar_uuid ""
                                                                                                     :currency ""
                                                                                                     :daily_limit {:currency ""
                                                                                                                   :value ""}
                                                                                                     :description ""
                                                                                                     :overdraft_limit {}
                                                                                                     :reason ""
                                                                                                     :reason_description ""
                                                                                                     :setting {:color ""
                                                                                                               :default_avatar_status ""
                                                                                                               :icon ""
                                                                                                               :restriction_chat ""
                                                                                                               :sdd_expiration_action ""}
                                                                                                     :status ""
                                                                                                     :sub_status ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account-joint/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"overdraft_limit\": {},\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account-joint/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"overdraft_limit\": {},\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account-joint/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"overdraft_limit\": {},\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account-joint/:itemId"

	payload := strings.NewReader("{\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"overdraft_limit\": {},\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account-joint/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 958

{
  "alias": [
    {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    }
  ],
  "all_co_owner": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "status": ""
    }
  ],
  "avatar_uuid": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "overdraft_limit": {},
  "reason": "",
  "reason_description": "",
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account-joint/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"overdraft_limit\": {},\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account-joint/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"overdraft_limit\": {},\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"overdraft_limit\": {},\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account-joint/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account-joint/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"overdraft_limit\": {},\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  alias: [
    {
      name: '',
      service: '',
      type: '',
      value: ''
    }
  ],
  all_co_owner: [
    {
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [
            {
              attachment_public_uuid: '',
              content_type: '',
              height: 0,
              width: 0
            }
          ],
          style: '',
          uuid: ''
        },
        country: '',
        display_name: '',
        public_nick_name: '',
        uuid: ''
      },
      status: ''
    }
  ],
  avatar_uuid: '',
  currency: '',
  daily_limit: {
    currency: '',
    value: ''
  },
  description: '',
  overdraft_limit: {},
  reason: '',
  reason_description: '',
  setting: {
    color: '',
    default_avatar_status: '',
    icon: '',
    restriction_chat: '',
    sdd_expiration_action: ''
  },
  status: '',
  sub_status: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account-joint/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account-joint/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    alias: [{name: '', service: '', type: '', value: ''}],
    all_co_owner: [
      {
        alias: {
          avatar: {
            anchor_uuid: '',
            image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
            style: '',
            uuid: ''
          },
          country: '',
          display_name: '',
          public_nick_name: '',
          uuid: ''
        },
        status: ''
      }
    ],
    avatar_uuid: '',
    currency: '',
    daily_limit: {currency: '', value: ''},
    description: '',
    overdraft_limit: {},
    reason: '',
    reason_description: '',
    setting: {
      color: '',
      default_avatar_status: '',
      icon: '',
      restriction_chat: '',
      sdd_expiration_action: ''
    },
    status: '',
    sub_status: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account-joint/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"alias":[{"name":"","service":"","type":"","value":""}],"all_co_owner":[{"alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"country":"","display_name":"","public_nick_name":"","uuid":""},"status":""}],"avatar_uuid":"","currency":"","daily_limit":{"currency":"","value":""},"description":"","overdraft_limit":{},"reason":"","reason_description":"","setting":{"color":"","default_avatar_status":"","icon":"","restriction_chat":"","sdd_expiration_action":""},"status":"","sub_status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account-joint/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "alias": [\n    {\n      "name": "",\n      "service": "",\n      "type": "",\n      "value": ""\n    }\n  ],\n  "all_co_owner": [\n    {\n      "alias": {\n        "avatar": {\n          "anchor_uuid": "",\n          "image": [\n            {\n              "attachment_public_uuid": "",\n              "content_type": "",\n              "height": 0,\n              "width": 0\n            }\n          ],\n          "style": "",\n          "uuid": ""\n        },\n        "country": "",\n        "display_name": "",\n        "public_nick_name": "",\n        "uuid": ""\n      },\n      "status": ""\n    }\n  ],\n  "avatar_uuid": "",\n  "currency": "",\n  "daily_limit": {\n    "currency": "",\n    "value": ""\n  },\n  "description": "",\n  "overdraft_limit": {},\n  "reason": "",\n  "reason_description": "",\n  "setting": {\n    "color": "",\n    "default_avatar_status": "",\n    "icon": "",\n    "restriction_chat": "",\n    "sdd_expiration_action": ""\n  },\n  "status": "",\n  "sub_status": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"overdraft_limit\": {},\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account-joint/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account-joint/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  alias: [{name: '', service: '', type: '', value: ''}],
  all_co_owner: [
    {
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
          style: '',
          uuid: ''
        },
        country: '',
        display_name: '',
        public_nick_name: '',
        uuid: ''
      },
      status: ''
    }
  ],
  avatar_uuid: '',
  currency: '',
  daily_limit: {currency: '', value: ''},
  description: '',
  overdraft_limit: {},
  reason: '',
  reason_description: '',
  setting: {
    color: '',
    default_avatar_status: '',
    icon: '',
    restriction_chat: '',
    sdd_expiration_action: ''
  },
  status: '',
  sub_status: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account-joint/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    alias: [{name: '', service: '', type: '', value: ''}],
    all_co_owner: [
      {
        alias: {
          avatar: {
            anchor_uuid: '',
            image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
            style: '',
            uuid: ''
          },
          country: '',
          display_name: '',
          public_nick_name: '',
          uuid: ''
        },
        status: ''
      }
    ],
    avatar_uuid: '',
    currency: '',
    daily_limit: {currency: '', value: ''},
    description: '',
    overdraft_limit: {},
    reason: '',
    reason_description: '',
    setting: {
      color: '',
      default_avatar_status: '',
      icon: '',
      restriction_chat: '',
      sdd_expiration_action: ''
    },
    status: '',
    sub_status: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account-joint/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  alias: [
    {
      name: '',
      service: '',
      type: '',
      value: ''
    }
  ],
  all_co_owner: [
    {
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [
            {
              attachment_public_uuid: '',
              content_type: '',
              height: 0,
              width: 0
            }
          ],
          style: '',
          uuid: ''
        },
        country: '',
        display_name: '',
        public_nick_name: '',
        uuid: ''
      },
      status: ''
    }
  ],
  avatar_uuid: '',
  currency: '',
  daily_limit: {
    currency: '',
    value: ''
  },
  description: '',
  overdraft_limit: {},
  reason: '',
  reason_description: '',
  setting: {
    color: '',
    default_avatar_status: '',
    icon: '',
    restriction_chat: '',
    sdd_expiration_action: ''
  },
  status: '',
  sub_status: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account-joint/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    alias: [{name: '', service: '', type: '', value: ''}],
    all_co_owner: [
      {
        alias: {
          avatar: {
            anchor_uuid: '',
            image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
            style: '',
            uuid: ''
          },
          country: '',
          display_name: '',
          public_nick_name: '',
          uuid: ''
        },
        status: ''
      }
    ],
    avatar_uuid: '',
    currency: '',
    daily_limit: {currency: '', value: ''},
    description: '',
    overdraft_limit: {},
    reason: '',
    reason_description: '',
    setting: {
      color: '',
      default_avatar_status: '',
      icon: '',
      restriction_chat: '',
      sdd_expiration_action: ''
    },
    status: '',
    sub_status: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account-joint/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"alias":[{"name":"","service":"","type":"","value":""}],"all_co_owner":[{"alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"country":"","display_name":"","public_nick_name":"","uuid":""},"status":""}],"avatar_uuid":"","currency":"","daily_limit":{"currency":"","value":""},"description":"","overdraft_limit":{},"reason":"","reason_description":"","setting":{"color":"","default_avatar_status":"","icon":"","restriction_chat":"","sdd_expiration_action":""},"status":"","sub_status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"alias": @[ @{ @"name": @"", @"service": @"", @"type": @"", @"value": @"" } ],
                              @"all_co_owner": @[ @{ @"alias": @{ @"avatar": @{ @"anchor_uuid": @"", @"image": @[ @{ @"attachment_public_uuid": @"", @"content_type": @"", @"height": @0, @"width": @0 } ], @"style": @"", @"uuid": @"" }, @"country": @"", @"display_name": @"", @"public_nick_name": @"", @"uuid": @"" }, @"status": @"" } ],
                              @"avatar_uuid": @"",
                              @"currency": @"",
                              @"daily_limit": @{ @"currency": @"", @"value": @"" },
                              @"description": @"",
                              @"overdraft_limit": @{  },
                              @"reason": @"",
                              @"reason_description": @"",
                              @"setting": @{ @"color": @"", @"default_avatar_status": @"", @"icon": @"", @"restriction_chat": @"", @"sdd_expiration_action": @"" },
                              @"status": @"",
                              @"sub_status": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account-joint/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account-joint/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"overdraft_limit\": {},\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account-joint/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'alias' => [
        [
                'name' => '',
                'service' => '',
                'type' => '',
                'value' => ''
        ]
    ],
    'all_co_owner' => [
        [
                'alias' => [
                                'avatar' => [
                                                                'anchor_uuid' => '',
                                                                'image' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'attachment_public_uuid' => '',
                                                                                                                                                                                                                                                                'content_type' => '',
                                                                                                                                                                                                                                                                'height' => 0,
                                                                                                                                                                                                                                                                'width' => 0
                                                                                                                                ]
                                                                ],
                                                                'style' => '',
                                                                'uuid' => ''
                                ],
                                'country' => '',
                                'display_name' => '',
                                'public_nick_name' => '',
                                'uuid' => ''
                ],
                'status' => ''
        ]
    ],
    'avatar_uuid' => '',
    'currency' => '',
    'daily_limit' => [
        'currency' => '',
        'value' => ''
    ],
    'description' => '',
    'overdraft_limit' => [
        
    ],
    'reason' => '',
    'reason_description' => '',
    'setting' => [
        'color' => '',
        'default_avatar_status' => '',
        'icon' => '',
        'restriction_chat' => '',
        'sdd_expiration_action' => ''
    ],
    'status' => '',
    'sub_status' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account-joint/:itemId', [
  'body' => '{
  "alias": [
    {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    }
  ],
  "all_co_owner": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "status": ""
    }
  ],
  "avatar_uuid": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "overdraft_limit": {},
  "reason": "",
  "reason_description": "",
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account-joint/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'alias' => [
    [
        'name' => '',
        'service' => '',
        'type' => '',
        'value' => ''
    ]
  ],
  'all_co_owner' => [
    [
        'alias' => [
                'avatar' => [
                                'anchor_uuid' => '',
                                'image' => [
                                                                [
                                                                                                                                'attachment_public_uuid' => '',
                                                                                                                                'content_type' => '',
                                                                                                                                'height' => 0,
                                                                                                                                'width' => 0
                                                                ]
                                ],
                                'style' => '',
                                'uuid' => ''
                ],
                'country' => '',
                'display_name' => '',
                'public_nick_name' => '',
                'uuid' => ''
        ],
        'status' => ''
    ]
  ],
  'avatar_uuid' => '',
  'currency' => '',
  'daily_limit' => [
    'currency' => '',
    'value' => ''
  ],
  'description' => '',
  'overdraft_limit' => [
    
  ],
  'reason' => '',
  'reason_description' => '',
  'setting' => [
    'color' => '',
    'default_avatar_status' => '',
    'icon' => '',
    'restriction_chat' => '',
    'sdd_expiration_action' => ''
  ],
  'status' => '',
  'sub_status' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'alias' => [
    [
        'name' => '',
        'service' => '',
        'type' => '',
        'value' => ''
    ]
  ],
  'all_co_owner' => [
    [
        'alias' => [
                'avatar' => [
                                'anchor_uuid' => '',
                                'image' => [
                                                                [
                                                                                                                                'attachment_public_uuid' => '',
                                                                                                                                'content_type' => '',
                                                                                                                                'height' => 0,
                                                                                                                                'width' => 0
                                                                ]
                                ],
                                'style' => '',
                                'uuid' => ''
                ],
                'country' => '',
                'display_name' => '',
                'public_nick_name' => '',
                'uuid' => ''
        ],
        'status' => ''
    ]
  ],
  'avatar_uuid' => '',
  'currency' => '',
  'daily_limit' => [
    'currency' => '',
    'value' => ''
  ],
  'description' => '',
  'overdraft_limit' => [
    
  ],
  'reason' => '',
  'reason_description' => '',
  'setting' => [
    'color' => '',
    'default_avatar_status' => '',
    'icon' => '',
    'restriction_chat' => '',
    'sdd_expiration_action' => ''
  ],
  'status' => '',
  'sub_status' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account-joint/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account-joint/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "alias": [
    {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    }
  ],
  "all_co_owner": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "status": ""
    }
  ],
  "avatar_uuid": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "overdraft_limit": {},
  "reason": "",
  "reason_description": "",
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account-joint/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "alias": [
    {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    }
  ],
  "all_co_owner": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "status": ""
    }
  ],
  "avatar_uuid": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "overdraft_limit": {},
  "reason": "",
  "reason_description": "",
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"overdraft_limit\": {},\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account-joint/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account-joint/:itemId"

payload = {
    "alias": [
        {
            "name": "",
            "service": "",
            "type": "",
            "value": ""
        }
    ],
    "all_co_owner": [
        {
            "alias": {
                "avatar": {
                    "anchor_uuid": "",
                    "image": [
                        {
                            "attachment_public_uuid": "",
                            "content_type": "",
                            "height": 0,
                            "width": 0
                        }
                    ],
                    "style": "",
                    "uuid": ""
                },
                "country": "",
                "display_name": "",
                "public_nick_name": "",
                "uuid": ""
            },
            "status": ""
        }
    ],
    "avatar_uuid": "",
    "currency": "",
    "daily_limit": {
        "currency": "",
        "value": ""
    },
    "description": "",
    "overdraft_limit": {},
    "reason": "",
    "reason_description": "",
    "setting": {
        "color": "",
        "default_avatar_status": "",
        "icon": "",
        "restriction_chat": "",
        "sdd_expiration_action": ""
    },
    "status": "",
    "sub_status": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account-joint/:itemId"

payload <- "{\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"overdraft_limit\": {},\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account-joint/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"overdraft_limit\": {},\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account-joint/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"overdraft_limit\": {},\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account-joint/:itemId";

    let payload = json!({
        "alias": (
            json!({
                "name": "",
                "service": "",
                "type": "",
                "value": ""
            })
        ),
        "all_co_owner": (
            json!({
                "alias": json!({
                    "avatar": json!({
                        "anchor_uuid": "",
                        "image": (
                            json!({
                                "attachment_public_uuid": "",
                                "content_type": "",
                                "height": 0,
                                "width": 0
                            })
                        ),
                        "style": "",
                        "uuid": ""
                    }),
                    "country": "",
                    "display_name": "",
                    "public_nick_name": "",
                    "uuid": ""
                }),
                "status": ""
            })
        ),
        "avatar_uuid": "",
        "currency": "",
        "daily_limit": json!({
            "currency": "",
            "value": ""
        }),
        "description": "",
        "overdraft_limit": json!({}),
        "reason": "",
        "reason_description": "",
        "setting": json!({
            "color": "",
            "default_avatar_status": "",
            "icon": "",
            "restriction_chat": "",
            "sdd_expiration_action": ""
        }),
        "status": "",
        "sub_status": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account-joint/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "alias": [
    {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    }
  ],
  "all_co_owner": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "status": ""
    }
  ],
  "avatar_uuid": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "overdraft_limit": {},
  "reason": "",
  "reason_description": "",
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}'
echo '{
  "alias": [
    {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    }
  ],
  "all_co_owner": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "status": ""
    }
  ],
  "avatar_uuid": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "overdraft_limit": {},
  "reason": "",
  "reason_description": "",
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account-joint/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "alias": [\n    {\n      "name": "",\n      "service": "",\n      "type": "",\n      "value": ""\n    }\n  ],\n  "all_co_owner": [\n    {\n      "alias": {\n        "avatar": {\n          "anchor_uuid": "",\n          "image": [\n            {\n              "attachment_public_uuid": "",\n              "content_type": "",\n              "height": 0,\n              "width": 0\n            }\n          ],\n          "style": "",\n          "uuid": ""\n        },\n        "country": "",\n        "display_name": "",\n        "public_nick_name": "",\n        "uuid": ""\n      },\n      "status": ""\n    }\n  ],\n  "avatar_uuid": "",\n  "currency": "",\n  "daily_limit": {\n    "currency": "",\n    "value": ""\n  },\n  "description": "",\n  "overdraft_limit": {},\n  "reason": "",\n  "reason_description": "",\n  "setting": {\n    "color": "",\n    "default_avatar_status": "",\n    "icon": "",\n    "restriction_chat": "",\n    "sdd_expiration_action": ""\n  },\n  "status": "",\n  "sub_status": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account-joint/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "alias": [
    [
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    ]
  ],
  "all_co_owner": [
    [
      "alias": [
        "avatar": [
          "anchor_uuid": "",
          "image": [
            [
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            ]
          ],
          "style": "",
          "uuid": ""
        ],
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      ],
      "status": ""
    ]
  ],
  "avatar_uuid": "",
  "currency": "",
  "daily_limit": [
    "currency": "",
    "value": ""
  ],
  "description": "",
  "overdraft_limit": [],
  "reason": "",
  "reason_description": "",
  "setting": [
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  ],
  "status": "",
  "sub_status": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account-joint/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_MonetaryAccountSavings_for_User
{{baseUrl}}/user/:userID/monetary-account-savings
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
BODY json

{
  "all_co_owner": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "status": ""
    }
  ],
  "avatar_uuid": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "reason": "",
  "reason_description": "",
  "savings_goal": {},
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account-savings");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"savings_goal\": {},\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account-savings" {:headers {:user-agent ""
                                                                                            :x-bunq-client-authentication ""}
                                                                                  :content-type :json
                                                                                  :form-params {:all_co_owner [{:alias {:avatar {:anchor_uuid ""
                                                                                                                                 :image [{:attachment_public_uuid ""
                                                                                                                                          :content_type ""
                                                                                                                                          :height 0
                                                                                                                                          :width 0}]
                                                                                                                                 :style ""
                                                                                                                                 :uuid ""}
                                                                                                                        :country ""
                                                                                                                        :display_name ""
                                                                                                                        :public_nick_name ""
                                                                                                                        :uuid ""}
                                                                                                                :status ""}]
                                                                                                :avatar_uuid ""
                                                                                                :currency ""
                                                                                                :daily_limit {:currency ""
                                                                                                              :value ""}
                                                                                                :description ""
                                                                                                :reason ""
                                                                                                :reason_description ""
                                                                                                :savings_goal {}
                                                                                                :setting {:color ""
                                                                                                          :default_avatar_status ""
                                                                                                          :icon ""
                                                                                                          :restriction_chat ""
                                                                                                          :sdd_expiration_action ""}
                                                                                                :status ""
                                                                                                :sub_status ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account-savings"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"savings_goal\": {},\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account-savings"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"savings_goal\": {},\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account-savings");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"savings_goal\": {},\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account-savings"

	payload := strings.NewReader("{\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"savings_goal\": {},\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account-savings HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 850

{
  "all_co_owner": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "status": ""
    }
  ],
  "avatar_uuid": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "reason": "",
  "reason_description": "",
  "savings_goal": {},
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account-savings")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"savings_goal\": {},\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account-savings"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"savings_goal\": {},\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"savings_goal\": {},\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account-savings")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account-savings")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"savings_goal\": {},\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  all_co_owner: [
    {
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [
            {
              attachment_public_uuid: '',
              content_type: '',
              height: 0,
              width: 0
            }
          ],
          style: '',
          uuid: ''
        },
        country: '',
        display_name: '',
        public_nick_name: '',
        uuid: ''
      },
      status: ''
    }
  ],
  avatar_uuid: '',
  currency: '',
  daily_limit: {
    currency: '',
    value: ''
  },
  description: '',
  reason: '',
  reason_description: '',
  savings_goal: {},
  setting: {
    color: '',
    default_avatar_status: '',
    icon: '',
    restriction_chat: '',
    sdd_expiration_action: ''
  },
  status: '',
  sub_status: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account-savings');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account-savings',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    all_co_owner: [
      {
        alias: {
          avatar: {
            anchor_uuid: '',
            image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
            style: '',
            uuid: ''
          },
          country: '',
          display_name: '',
          public_nick_name: '',
          uuid: ''
        },
        status: ''
      }
    ],
    avatar_uuid: '',
    currency: '',
    daily_limit: {currency: '', value: ''},
    description: '',
    reason: '',
    reason_description: '',
    savings_goal: {},
    setting: {
      color: '',
      default_avatar_status: '',
      icon: '',
      restriction_chat: '',
      sdd_expiration_action: ''
    },
    status: '',
    sub_status: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account-savings';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"all_co_owner":[{"alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"country":"","display_name":"","public_nick_name":"","uuid":""},"status":""}],"avatar_uuid":"","currency":"","daily_limit":{"currency":"","value":""},"description":"","reason":"","reason_description":"","savings_goal":{},"setting":{"color":"","default_avatar_status":"","icon":"","restriction_chat":"","sdd_expiration_action":""},"status":"","sub_status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account-savings',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "all_co_owner": [\n    {\n      "alias": {\n        "avatar": {\n          "anchor_uuid": "",\n          "image": [\n            {\n              "attachment_public_uuid": "",\n              "content_type": "",\n              "height": 0,\n              "width": 0\n            }\n          ],\n          "style": "",\n          "uuid": ""\n        },\n        "country": "",\n        "display_name": "",\n        "public_nick_name": "",\n        "uuid": ""\n      },\n      "status": ""\n    }\n  ],\n  "avatar_uuid": "",\n  "currency": "",\n  "daily_limit": {\n    "currency": "",\n    "value": ""\n  },\n  "description": "",\n  "reason": "",\n  "reason_description": "",\n  "savings_goal": {},\n  "setting": {\n    "color": "",\n    "default_avatar_status": "",\n    "icon": "",\n    "restriction_chat": "",\n    "sdd_expiration_action": ""\n  },\n  "status": "",\n  "sub_status": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"savings_goal\": {},\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account-savings")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account-savings',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  all_co_owner: [
    {
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
          style: '',
          uuid: ''
        },
        country: '',
        display_name: '',
        public_nick_name: '',
        uuid: ''
      },
      status: ''
    }
  ],
  avatar_uuid: '',
  currency: '',
  daily_limit: {currency: '', value: ''},
  description: '',
  reason: '',
  reason_description: '',
  savings_goal: {},
  setting: {
    color: '',
    default_avatar_status: '',
    icon: '',
    restriction_chat: '',
    sdd_expiration_action: ''
  },
  status: '',
  sub_status: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account-savings',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    all_co_owner: [
      {
        alias: {
          avatar: {
            anchor_uuid: '',
            image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
            style: '',
            uuid: ''
          },
          country: '',
          display_name: '',
          public_nick_name: '',
          uuid: ''
        },
        status: ''
      }
    ],
    avatar_uuid: '',
    currency: '',
    daily_limit: {currency: '', value: ''},
    description: '',
    reason: '',
    reason_description: '',
    savings_goal: {},
    setting: {
      color: '',
      default_avatar_status: '',
      icon: '',
      restriction_chat: '',
      sdd_expiration_action: ''
    },
    status: '',
    sub_status: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account-savings');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  all_co_owner: [
    {
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [
            {
              attachment_public_uuid: '',
              content_type: '',
              height: 0,
              width: 0
            }
          ],
          style: '',
          uuid: ''
        },
        country: '',
        display_name: '',
        public_nick_name: '',
        uuid: ''
      },
      status: ''
    }
  ],
  avatar_uuid: '',
  currency: '',
  daily_limit: {
    currency: '',
    value: ''
  },
  description: '',
  reason: '',
  reason_description: '',
  savings_goal: {},
  setting: {
    color: '',
    default_avatar_status: '',
    icon: '',
    restriction_chat: '',
    sdd_expiration_action: ''
  },
  status: '',
  sub_status: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account-savings',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    all_co_owner: [
      {
        alias: {
          avatar: {
            anchor_uuid: '',
            image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
            style: '',
            uuid: ''
          },
          country: '',
          display_name: '',
          public_nick_name: '',
          uuid: ''
        },
        status: ''
      }
    ],
    avatar_uuid: '',
    currency: '',
    daily_limit: {currency: '', value: ''},
    description: '',
    reason: '',
    reason_description: '',
    savings_goal: {},
    setting: {
      color: '',
      default_avatar_status: '',
      icon: '',
      restriction_chat: '',
      sdd_expiration_action: ''
    },
    status: '',
    sub_status: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account-savings';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"all_co_owner":[{"alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"country":"","display_name":"","public_nick_name":"","uuid":""},"status":""}],"avatar_uuid":"","currency":"","daily_limit":{"currency":"","value":""},"description":"","reason":"","reason_description":"","savings_goal":{},"setting":{"color":"","default_avatar_status":"","icon":"","restriction_chat":"","sdd_expiration_action":""},"status":"","sub_status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"all_co_owner": @[ @{ @"alias": @{ @"avatar": @{ @"anchor_uuid": @"", @"image": @[ @{ @"attachment_public_uuid": @"", @"content_type": @"", @"height": @0, @"width": @0 } ], @"style": @"", @"uuid": @"" }, @"country": @"", @"display_name": @"", @"public_nick_name": @"", @"uuid": @"" }, @"status": @"" } ],
                              @"avatar_uuid": @"",
                              @"currency": @"",
                              @"daily_limit": @{ @"currency": @"", @"value": @"" },
                              @"description": @"",
                              @"reason": @"",
                              @"reason_description": @"",
                              @"savings_goal": @{  },
                              @"setting": @{ @"color": @"", @"default_avatar_status": @"", @"icon": @"", @"restriction_chat": @"", @"sdd_expiration_action": @"" },
                              @"status": @"",
                              @"sub_status": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account-savings"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account-savings" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"savings_goal\": {},\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account-savings",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'all_co_owner' => [
        [
                'alias' => [
                                'avatar' => [
                                                                'anchor_uuid' => '',
                                                                'image' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'attachment_public_uuid' => '',
                                                                                                                                                                                                                                                                'content_type' => '',
                                                                                                                                                                                                                                                                'height' => 0,
                                                                                                                                                                                                                                                                'width' => 0
                                                                                                                                ]
                                                                ],
                                                                'style' => '',
                                                                'uuid' => ''
                                ],
                                'country' => '',
                                'display_name' => '',
                                'public_nick_name' => '',
                                'uuid' => ''
                ],
                'status' => ''
        ]
    ],
    'avatar_uuid' => '',
    'currency' => '',
    'daily_limit' => [
        'currency' => '',
        'value' => ''
    ],
    'description' => '',
    'reason' => '',
    'reason_description' => '',
    'savings_goal' => [
        
    ],
    'setting' => [
        'color' => '',
        'default_avatar_status' => '',
        'icon' => '',
        'restriction_chat' => '',
        'sdd_expiration_action' => ''
    ],
    'status' => '',
    'sub_status' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account-savings', [
  'body' => '{
  "all_co_owner": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "status": ""
    }
  ],
  "avatar_uuid": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "reason": "",
  "reason_description": "",
  "savings_goal": {},
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account-savings');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'all_co_owner' => [
    [
        'alias' => [
                'avatar' => [
                                'anchor_uuid' => '',
                                'image' => [
                                                                [
                                                                                                                                'attachment_public_uuid' => '',
                                                                                                                                'content_type' => '',
                                                                                                                                'height' => 0,
                                                                                                                                'width' => 0
                                                                ]
                                ],
                                'style' => '',
                                'uuid' => ''
                ],
                'country' => '',
                'display_name' => '',
                'public_nick_name' => '',
                'uuid' => ''
        ],
        'status' => ''
    ]
  ],
  'avatar_uuid' => '',
  'currency' => '',
  'daily_limit' => [
    'currency' => '',
    'value' => ''
  ],
  'description' => '',
  'reason' => '',
  'reason_description' => '',
  'savings_goal' => [
    
  ],
  'setting' => [
    'color' => '',
    'default_avatar_status' => '',
    'icon' => '',
    'restriction_chat' => '',
    'sdd_expiration_action' => ''
  ],
  'status' => '',
  'sub_status' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'all_co_owner' => [
    [
        'alias' => [
                'avatar' => [
                                'anchor_uuid' => '',
                                'image' => [
                                                                [
                                                                                                                                'attachment_public_uuid' => '',
                                                                                                                                'content_type' => '',
                                                                                                                                'height' => 0,
                                                                                                                                'width' => 0
                                                                ]
                                ],
                                'style' => '',
                                'uuid' => ''
                ],
                'country' => '',
                'display_name' => '',
                'public_nick_name' => '',
                'uuid' => ''
        ],
        'status' => ''
    ]
  ],
  'avatar_uuid' => '',
  'currency' => '',
  'daily_limit' => [
    'currency' => '',
    'value' => ''
  ],
  'description' => '',
  'reason' => '',
  'reason_description' => '',
  'savings_goal' => [
    
  ],
  'setting' => [
    'color' => '',
    'default_avatar_status' => '',
    'icon' => '',
    'restriction_chat' => '',
    'sdd_expiration_action' => ''
  ],
  'status' => '',
  'sub_status' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account-savings');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account-savings' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "all_co_owner": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "status": ""
    }
  ],
  "avatar_uuid": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "reason": "",
  "reason_description": "",
  "savings_goal": {},
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account-savings' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "all_co_owner": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "status": ""
    }
  ],
  "avatar_uuid": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "reason": "",
  "reason_description": "",
  "savings_goal": {},
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"savings_goal\": {},\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account-savings", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account-savings"

payload = {
    "all_co_owner": [
        {
            "alias": {
                "avatar": {
                    "anchor_uuid": "",
                    "image": [
                        {
                            "attachment_public_uuid": "",
                            "content_type": "",
                            "height": 0,
                            "width": 0
                        }
                    ],
                    "style": "",
                    "uuid": ""
                },
                "country": "",
                "display_name": "",
                "public_nick_name": "",
                "uuid": ""
            },
            "status": ""
        }
    ],
    "avatar_uuid": "",
    "currency": "",
    "daily_limit": {
        "currency": "",
        "value": ""
    },
    "description": "",
    "reason": "",
    "reason_description": "",
    "savings_goal": {},
    "setting": {
        "color": "",
        "default_avatar_status": "",
        "icon": "",
        "restriction_chat": "",
        "sdd_expiration_action": ""
    },
    "status": "",
    "sub_status": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account-savings"

payload <- "{\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"savings_goal\": {},\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account-savings")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"savings_goal\": {},\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account-savings') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"savings_goal\": {},\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account-savings";

    let payload = json!({
        "all_co_owner": (
            json!({
                "alias": json!({
                    "avatar": json!({
                        "anchor_uuid": "",
                        "image": (
                            json!({
                                "attachment_public_uuid": "",
                                "content_type": "",
                                "height": 0,
                                "width": 0
                            })
                        ),
                        "style": "",
                        "uuid": ""
                    }),
                    "country": "",
                    "display_name": "",
                    "public_nick_name": "",
                    "uuid": ""
                }),
                "status": ""
            })
        ),
        "avatar_uuid": "",
        "currency": "",
        "daily_limit": json!({
            "currency": "",
            "value": ""
        }),
        "description": "",
        "reason": "",
        "reason_description": "",
        "savings_goal": json!({}),
        "setting": json!({
            "color": "",
            "default_avatar_status": "",
            "icon": "",
            "restriction_chat": "",
            "sdd_expiration_action": ""
        }),
        "status": "",
        "sub_status": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account-savings \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "all_co_owner": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "status": ""
    }
  ],
  "avatar_uuid": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "reason": "",
  "reason_description": "",
  "savings_goal": {},
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}'
echo '{
  "all_co_owner": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "status": ""
    }
  ],
  "avatar_uuid": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "reason": "",
  "reason_description": "",
  "savings_goal": {},
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account-savings \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "all_co_owner": [\n    {\n      "alias": {\n        "avatar": {\n          "anchor_uuid": "",\n          "image": [\n            {\n              "attachment_public_uuid": "",\n              "content_type": "",\n              "height": 0,\n              "width": 0\n            }\n          ],\n          "style": "",\n          "uuid": ""\n        },\n        "country": "",\n        "display_name": "",\n        "public_nick_name": "",\n        "uuid": ""\n      },\n      "status": ""\n    }\n  ],\n  "avatar_uuid": "",\n  "currency": "",\n  "daily_limit": {\n    "currency": "",\n    "value": ""\n  },\n  "description": "",\n  "reason": "",\n  "reason_description": "",\n  "savings_goal": {},\n  "setting": {\n    "color": "",\n    "default_avatar_status": "",\n    "icon": "",\n    "restriction_chat": "",\n    "sdd_expiration_action": ""\n  },\n  "status": "",\n  "sub_status": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account-savings
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "all_co_owner": [
    [
      "alias": [
        "avatar": [
          "anchor_uuid": "",
          "image": [
            [
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            ]
          ],
          "style": "",
          "uuid": ""
        ],
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      ],
      "status": ""
    ]
  ],
  "avatar_uuid": "",
  "currency": "",
  "daily_limit": [
    "currency": "",
    "value": ""
  ],
  "description": "",
  "reason": "",
  "reason_description": "",
  "savings_goal": [],
  "setting": [
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  ],
  "status": "",
  "sub_status": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account-savings")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_MonetaryAccountSavings_for_User
{{baseUrl}}/user/:userID/monetary-account-savings
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account-savings");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account-savings" {:headers {:user-agent ""
                                                                                           :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account-savings"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account-savings"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account-savings");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account-savings"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account-savings HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account-savings")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account-savings"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account-savings")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account-savings")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account-savings');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account-savings',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account-savings';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account-savings',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account-savings")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account-savings',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account-savings',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account-savings');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account-savings',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account-savings';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account-savings"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account-savings" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account-savings",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account-savings', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account-savings');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account-savings');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account-savings' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account-savings' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account-savings", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account-savings"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account-savings"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account-savings")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account-savings') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account-savings";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account-savings \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account-savings \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account-savings
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account-savings")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_MonetaryAccountSavings_for_User
{{baseUrl}}/user/:userID/monetary-account-savings/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account-savings/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account-savings/:itemId" {:headers {:user-agent ""
                                                                                                   :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account-savings/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account-savings/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account-savings/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account-savings/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account-savings/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account-savings/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account-savings/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account-savings/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account-savings/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account-savings/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account-savings/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account-savings/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account-savings/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account-savings/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account-savings/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account-savings/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account-savings/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account-savings/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account-savings/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account-savings/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account-savings/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account-savings/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account-savings/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account-savings/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account-savings/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account-savings/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account-savings/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account-savings/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account-savings/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account-savings/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account-savings/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account-savings/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account-savings/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account-savings/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account-savings/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account-savings/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account-savings/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_MonetaryAccountSavings_for_User
{{baseUrl}}/user/:userID/monetary-account-savings/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
BODY json

{
  "all_co_owner": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "status": ""
    }
  ],
  "avatar_uuid": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "reason": "",
  "reason_description": "",
  "savings_goal": {},
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account-savings/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"savings_goal\": {},\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account-savings/:itemId" {:headers {:user-agent ""
                                                                                                   :x-bunq-client-authentication ""}
                                                                                         :content-type :json
                                                                                         :form-params {:all_co_owner [{:alias {:avatar {:anchor_uuid ""
                                                                                                                                        :image [{:attachment_public_uuid ""
                                                                                                                                                 :content_type ""
                                                                                                                                                 :height 0
                                                                                                                                                 :width 0}]
                                                                                                                                        :style ""
                                                                                                                                        :uuid ""}
                                                                                                                               :country ""
                                                                                                                               :display_name ""
                                                                                                                               :public_nick_name ""
                                                                                                                               :uuid ""}
                                                                                                                       :status ""}]
                                                                                                       :avatar_uuid ""
                                                                                                       :currency ""
                                                                                                       :daily_limit {:currency ""
                                                                                                                     :value ""}
                                                                                                       :description ""
                                                                                                       :reason ""
                                                                                                       :reason_description ""
                                                                                                       :savings_goal {}
                                                                                                       :setting {:color ""
                                                                                                                 :default_avatar_status ""
                                                                                                                 :icon ""
                                                                                                                 :restriction_chat ""
                                                                                                                 :sdd_expiration_action ""}
                                                                                                       :status ""
                                                                                                       :sub_status ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account-savings/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"savings_goal\": {},\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account-savings/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"savings_goal\": {},\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account-savings/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"savings_goal\": {},\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account-savings/:itemId"

	payload := strings.NewReader("{\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"savings_goal\": {},\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account-savings/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 850

{
  "all_co_owner": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "status": ""
    }
  ],
  "avatar_uuid": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "reason": "",
  "reason_description": "",
  "savings_goal": {},
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account-savings/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"savings_goal\": {},\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account-savings/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"savings_goal\": {},\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"savings_goal\": {},\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account-savings/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account-savings/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"savings_goal\": {},\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  all_co_owner: [
    {
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [
            {
              attachment_public_uuid: '',
              content_type: '',
              height: 0,
              width: 0
            }
          ],
          style: '',
          uuid: ''
        },
        country: '',
        display_name: '',
        public_nick_name: '',
        uuid: ''
      },
      status: ''
    }
  ],
  avatar_uuid: '',
  currency: '',
  daily_limit: {
    currency: '',
    value: ''
  },
  description: '',
  reason: '',
  reason_description: '',
  savings_goal: {},
  setting: {
    color: '',
    default_avatar_status: '',
    icon: '',
    restriction_chat: '',
    sdd_expiration_action: ''
  },
  status: '',
  sub_status: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account-savings/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account-savings/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    all_co_owner: [
      {
        alias: {
          avatar: {
            anchor_uuid: '',
            image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
            style: '',
            uuid: ''
          },
          country: '',
          display_name: '',
          public_nick_name: '',
          uuid: ''
        },
        status: ''
      }
    ],
    avatar_uuid: '',
    currency: '',
    daily_limit: {currency: '', value: ''},
    description: '',
    reason: '',
    reason_description: '',
    savings_goal: {},
    setting: {
      color: '',
      default_avatar_status: '',
      icon: '',
      restriction_chat: '',
      sdd_expiration_action: ''
    },
    status: '',
    sub_status: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account-savings/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"all_co_owner":[{"alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"country":"","display_name":"","public_nick_name":"","uuid":""},"status":""}],"avatar_uuid":"","currency":"","daily_limit":{"currency":"","value":""},"description":"","reason":"","reason_description":"","savings_goal":{},"setting":{"color":"","default_avatar_status":"","icon":"","restriction_chat":"","sdd_expiration_action":""},"status":"","sub_status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account-savings/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "all_co_owner": [\n    {\n      "alias": {\n        "avatar": {\n          "anchor_uuid": "",\n          "image": [\n            {\n              "attachment_public_uuid": "",\n              "content_type": "",\n              "height": 0,\n              "width": 0\n            }\n          ],\n          "style": "",\n          "uuid": ""\n        },\n        "country": "",\n        "display_name": "",\n        "public_nick_name": "",\n        "uuid": ""\n      },\n      "status": ""\n    }\n  ],\n  "avatar_uuid": "",\n  "currency": "",\n  "daily_limit": {\n    "currency": "",\n    "value": ""\n  },\n  "description": "",\n  "reason": "",\n  "reason_description": "",\n  "savings_goal": {},\n  "setting": {\n    "color": "",\n    "default_avatar_status": "",\n    "icon": "",\n    "restriction_chat": "",\n    "sdd_expiration_action": ""\n  },\n  "status": "",\n  "sub_status": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"savings_goal\": {},\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account-savings/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account-savings/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  all_co_owner: [
    {
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
          style: '',
          uuid: ''
        },
        country: '',
        display_name: '',
        public_nick_name: '',
        uuid: ''
      },
      status: ''
    }
  ],
  avatar_uuid: '',
  currency: '',
  daily_limit: {currency: '', value: ''},
  description: '',
  reason: '',
  reason_description: '',
  savings_goal: {},
  setting: {
    color: '',
    default_avatar_status: '',
    icon: '',
    restriction_chat: '',
    sdd_expiration_action: ''
  },
  status: '',
  sub_status: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account-savings/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    all_co_owner: [
      {
        alias: {
          avatar: {
            anchor_uuid: '',
            image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
            style: '',
            uuid: ''
          },
          country: '',
          display_name: '',
          public_nick_name: '',
          uuid: ''
        },
        status: ''
      }
    ],
    avatar_uuid: '',
    currency: '',
    daily_limit: {currency: '', value: ''},
    description: '',
    reason: '',
    reason_description: '',
    savings_goal: {},
    setting: {
      color: '',
      default_avatar_status: '',
      icon: '',
      restriction_chat: '',
      sdd_expiration_action: ''
    },
    status: '',
    sub_status: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account-savings/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  all_co_owner: [
    {
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [
            {
              attachment_public_uuid: '',
              content_type: '',
              height: 0,
              width: 0
            }
          ],
          style: '',
          uuid: ''
        },
        country: '',
        display_name: '',
        public_nick_name: '',
        uuid: ''
      },
      status: ''
    }
  ],
  avatar_uuid: '',
  currency: '',
  daily_limit: {
    currency: '',
    value: ''
  },
  description: '',
  reason: '',
  reason_description: '',
  savings_goal: {},
  setting: {
    color: '',
    default_avatar_status: '',
    icon: '',
    restriction_chat: '',
    sdd_expiration_action: ''
  },
  status: '',
  sub_status: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account-savings/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    all_co_owner: [
      {
        alias: {
          avatar: {
            anchor_uuid: '',
            image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
            style: '',
            uuid: ''
          },
          country: '',
          display_name: '',
          public_nick_name: '',
          uuid: ''
        },
        status: ''
      }
    ],
    avatar_uuid: '',
    currency: '',
    daily_limit: {currency: '', value: ''},
    description: '',
    reason: '',
    reason_description: '',
    savings_goal: {},
    setting: {
      color: '',
      default_avatar_status: '',
      icon: '',
      restriction_chat: '',
      sdd_expiration_action: ''
    },
    status: '',
    sub_status: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account-savings/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"all_co_owner":[{"alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"country":"","display_name":"","public_nick_name":"","uuid":""},"status":""}],"avatar_uuid":"","currency":"","daily_limit":{"currency":"","value":""},"description":"","reason":"","reason_description":"","savings_goal":{},"setting":{"color":"","default_avatar_status":"","icon":"","restriction_chat":"","sdd_expiration_action":""},"status":"","sub_status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"all_co_owner": @[ @{ @"alias": @{ @"avatar": @{ @"anchor_uuid": @"", @"image": @[ @{ @"attachment_public_uuid": @"", @"content_type": @"", @"height": @0, @"width": @0 } ], @"style": @"", @"uuid": @"" }, @"country": @"", @"display_name": @"", @"public_nick_name": @"", @"uuid": @"" }, @"status": @"" } ],
                              @"avatar_uuid": @"",
                              @"currency": @"",
                              @"daily_limit": @{ @"currency": @"", @"value": @"" },
                              @"description": @"",
                              @"reason": @"",
                              @"reason_description": @"",
                              @"savings_goal": @{  },
                              @"setting": @{ @"color": @"", @"default_avatar_status": @"", @"icon": @"", @"restriction_chat": @"", @"sdd_expiration_action": @"" },
                              @"status": @"",
                              @"sub_status": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account-savings/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account-savings/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"savings_goal\": {},\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account-savings/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'all_co_owner' => [
        [
                'alias' => [
                                'avatar' => [
                                                                'anchor_uuid' => '',
                                                                'image' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'attachment_public_uuid' => '',
                                                                                                                                                                                                                                                                'content_type' => '',
                                                                                                                                                                                                                                                                'height' => 0,
                                                                                                                                                                                                                                                                'width' => 0
                                                                                                                                ]
                                                                ],
                                                                'style' => '',
                                                                'uuid' => ''
                                ],
                                'country' => '',
                                'display_name' => '',
                                'public_nick_name' => '',
                                'uuid' => ''
                ],
                'status' => ''
        ]
    ],
    'avatar_uuid' => '',
    'currency' => '',
    'daily_limit' => [
        'currency' => '',
        'value' => ''
    ],
    'description' => '',
    'reason' => '',
    'reason_description' => '',
    'savings_goal' => [
        
    ],
    'setting' => [
        'color' => '',
        'default_avatar_status' => '',
        'icon' => '',
        'restriction_chat' => '',
        'sdd_expiration_action' => ''
    ],
    'status' => '',
    'sub_status' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account-savings/:itemId', [
  'body' => '{
  "all_co_owner": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "status": ""
    }
  ],
  "avatar_uuid": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "reason": "",
  "reason_description": "",
  "savings_goal": {},
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account-savings/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'all_co_owner' => [
    [
        'alias' => [
                'avatar' => [
                                'anchor_uuid' => '',
                                'image' => [
                                                                [
                                                                                                                                'attachment_public_uuid' => '',
                                                                                                                                'content_type' => '',
                                                                                                                                'height' => 0,
                                                                                                                                'width' => 0
                                                                ]
                                ],
                                'style' => '',
                                'uuid' => ''
                ],
                'country' => '',
                'display_name' => '',
                'public_nick_name' => '',
                'uuid' => ''
        ],
        'status' => ''
    ]
  ],
  'avatar_uuid' => '',
  'currency' => '',
  'daily_limit' => [
    'currency' => '',
    'value' => ''
  ],
  'description' => '',
  'reason' => '',
  'reason_description' => '',
  'savings_goal' => [
    
  ],
  'setting' => [
    'color' => '',
    'default_avatar_status' => '',
    'icon' => '',
    'restriction_chat' => '',
    'sdd_expiration_action' => ''
  ],
  'status' => '',
  'sub_status' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'all_co_owner' => [
    [
        'alias' => [
                'avatar' => [
                                'anchor_uuid' => '',
                                'image' => [
                                                                [
                                                                                                                                'attachment_public_uuid' => '',
                                                                                                                                'content_type' => '',
                                                                                                                                'height' => 0,
                                                                                                                                'width' => 0
                                                                ]
                                ],
                                'style' => '',
                                'uuid' => ''
                ],
                'country' => '',
                'display_name' => '',
                'public_nick_name' => '',
                'uuid' => ''
        ],
        'status' => ''
    ]
  ],
  'avatar_uuid' => '',
  'currency' => '',
  'daily_limit' => [
    'currency' => '',
    'value' => ''
  ],
  'description' => '',
  'reason' => '',
  'reason_description' => '',
  'savings_goal' => [
    
  ],
  'setting' => [
    'color' => '',
    'default_avatar_status' => '',
    'icon' => '',
    'restriction_chat' => '',
    'sdd_expiration_action' => ''
  ],
  'status' => '',
  'sub_status' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account-savings/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account-savings/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "all_co_owner": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "status": ""
    }
  ],
  "avatar_uuid": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "reason": "",
  "reason_description": "",
  "savings_goal": {},
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account-savings/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "all_co_owner": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "status": ""
    }
  ],
  "avatar_uuid": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "reason": "",
  "reason_description": "",
  "savings_goal": {},
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"savings_goal\": {},\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account-savings/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account-savings/:itemId"

payload = {
    "all_co_owner": [
        {
            "alias": {
                "avatar": {
                    "anchor_uuid": "",
                    "image": [
                        {
                            "attachment_public_uuid": "",
                            "content_type": "",
                            "height": 0,
                            "width": 0
                        }
                    ],
                    "style": "",
                    "uuid": ""
                },
                "country": "",
                "display_name": "",
                "public_nick_name": "",
                "uuid": ""
            },
            "status": ""
        }
    ],
    "avatar_uuid": "",
    "currency": "",
    "daily_limit": {
        "currency": "",
        "value": ""
    },
    "description": "",
    "reason": "",
    "reason_description": "",
    "savings_goal": {},
    "setting": {
        "color": "",
        "default_avatar_status": "",
        "icon": "",
        "restriction_chat": "",
        "sdd_expiration_action": ""
    },
    "status": "",
    "sub_status": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account-savings/:itemId"

payload <- "{\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"savings_goal\": {},\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account-savings/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"savings_goal\": {},\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account-savings/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"all_co_owner\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"status\": \"\"\n    }\n  ],\n  \"avatar_uuid\": \"\",\n  \"currency\": \"\",\n  \"daily_limit\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"description\": \"\",\n  \"reason\": \"\",\n  \"reason_description\": \"\",\n  \"savings_goal\": {},\n  \"setting\": {\n    \"color\": \"\",\n    \"default_avatar_status\": \"\",\n    \"icon\": \"\",\n    \"restriction_chat\": \"\",\n    \"sdd_expiration_action\": \"\"\n  },\n  \"status\": \"\",\n  \"sub_status\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account-savings/:itemId";

    let payload = json!({
        "all_co_owner": (
            json!({
                "alias": json!({
                    "avatar": json!({
                        "anchor_uuid": "",
                        "image": (
                            json!({
                                "attachment_public_uuid": "",
                                "content_type": "",
                                "height": 0,
                                "width": 0
                            })
                        ),
                        "style": "",
                        "uuid": ""
                    }),
                    "country": "",
                    "display_name": "",
                    "public_nick_name": "",
                    "uuid": ""
                }),
                "status": ""
            })
        ),
        "avatar_uuid": "",
        "currency": "",
        "daily_limit": json!({
            "currency": "",
            "value": ""
        }),
        "description": "",
        "reason": "",
        "reason_description": "",
        "savings_goal": json!({}),
        "setting": json!({
            "color": "",
            "default_avatar_status": "",
            "icon": "",
            "restriction_chat": "",
            "sdd_expiration_action": ""
        }),
        "status": "",
        "sub_status": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account-savings/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "all_co_owner": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "status": ""
    }
  ],
  "avatar_uuid": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "reason": "",
  "reason_description": "",
  "savings_goal": {},
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}'
echo '{
  "all_co_owner": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "status": ""
    }
  ],
  "avatar_uuid": "",
  "currency": "",
  "daily_limit": {
    "currency": "",
    "value": ""
  },
  "description": "",
  "reason": "",
  "reason_description": "",
  "savings_goal": {},
  "setting": {
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  },
  "status": "",
  "sub_status": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account-savings/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "all_co_owner": [\n    {\n      "alias": {\n        "avatar": {\n          "anchor_uuid": "",\n          "image": [\n            {\n              "attachment_public_uuid": "",\n              "content_type": "",\n              "height": 0,\n              "width": 0\n            }\n          ],\n          "style": "",\n          "uuid": ""\n        },\n        "country": "",\n        "display_name": "",\n        "public_nick_name": "",\n        "uuid": ""\n      },\n      "status": ""\n    }\n  ],\n  "avatar_uuid": "",\n  "currency": "",\n  "daily_limit": {\n    "currency": "",\n    "value": ""\n  },\n  "description": "",\n  "reason": "",\n  "reason_description": "",\n  "savings_goal": {},\n  "setting": {\n    "color": "",\n    "default_avatar_status": "",\n    "icon": "",\n    "restriction_chat": "",\n    "sdd_expiration_action": ""\n  },\n  "status": "",\n  "sub_status": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account-savings/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "all_co_owner": [
    [
      "alias": [
        "avatar": [
          "anchor_uuid": "",
          "image": [
            [
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            ]
          ],
          "style": "",
          "uuid": ""
        ],
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      ],
      "status": ""
    ]
  ],
  "avatar_uuid": "",
  "currency": "",
  "daily_limit": [
    "currency": "",
    "value": ""
  ],
  "description": "",
  "reason": "",
  "reason_description": "",
  "savings_goal": [],
  "setting": [
    "color": "",
    "default_avatar_status": "",
    "icon": "",
    "restriction_chat": "",
    "sdd_expiration_action": ""
  ],
  "status": "",
  "sub_status": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account-savings/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_Name_for_UserCompany
{{baseUrl}}/user-company/:user-companyID/name
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

user-companyID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user-company/:user-companyID/name");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user-company/:user-companyID/name" {:headers {:user-agent ""
                                                                                       :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user-company/:user-companyID/name"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user-company/:user-companyID/name"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user-company/:user-companyID/name");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user-company/:user-companyID/name"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user-company/:user-companyID/name HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user-company/:user-companyID/name")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user-company/:user-companyID/name"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user-company/:user-companyID/name")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user-company/:user-companyID/name")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user-company/:user-companyID/name');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user-company/:user-companyID/name',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user-company/:user-companyID/name';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user-company/:user-companyID/name',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user-company/:user-companyID/name")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user-company/:user-companyID/name',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user-company/:user-companyID/name',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user-company/:user-companyID/name');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user-company/:user-companyID/name',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user-company/:user-companyID/name';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user-company/:user-companyID/name"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user-company/:user-companyID/name" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user-company/:user-companyID/name",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user-company/:user-companyID/name', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user-company/:user-companyID/name');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user-company/:user-companyID/name');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user-company/:user-companyID/name' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user-company/:user-companyID/name' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user-company/:user-companyID/name", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user-company/:user-companyID/name"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user-company/:user-companyID/name"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user-company/:user-companyID/name")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user-company/:user-companyID/name') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user-company/:user-companyID/name";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user-company/:user-companyID/name \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user-company/:user-companyID/name \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user-company/:user-companyID/name
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user-company/:user-companyID/name")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_NoteAttachment_for_User_MonetaryAccount_BunqmeFundraiserResult
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
bunqme-fundraiser-resultID
BODY json

{
  "attachment_id": 0,
  "description": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment" {:headers {:user-agent ""
                                                                                                                                                                             :x-bunq-client-authentication ""}
                                                                                                                                                                   :content-type :json
                                                                                                                                                                   :form-params {:attachment_id 0
                                                                                                                                                                                 :description ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment"

	payload := strings.NewReader("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 45

{
  "attachment_id": 0,
  "description": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  attachment_id: 0,
  description: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "attachment_id": 0,\n  "description": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({attachment_id: 0, description: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {attachment_id: 0, description: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  attachment_id: 0,
  description: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"attachment_id": @0,
                              @"description": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'attachment_id' => 0,
    'description' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment', [
  'body' => '{
  "attachment_id": 0,
  "description": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment"

payload = {
    "attachment_id": 0,
    "description": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment"

payload <- "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment";

    let payload = json!({
        "attachment_id": 0,
        "description": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "attachment_id": 0,
  "description": ""
}'
echo '{
  "attachment_id": 0,
  "description": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "attachment_id": 0,\n  "description": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "attachment_id": 0,
  "description": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_NoteAttachment_for_User_MonetaryAccount_DraftPayment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
draft-paymentID
BODY json

{
  "attachment_id": 0,
  "description": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment" {:headers {:user-agent ""
                                                                                                                                                       :x-bunq-client-authentication ""}
                                                                                                                                             :content-type :json
                                                                                                                                             :form-params {:attachment_id 0
                                                                                                                                                           :description ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment"

	payload := strings.NewReader("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 45

{
  "attachment_id": 0,
  "description": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  attachment_id: 0,
  description: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "attachment_id": 0,\n  "description": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({attachment_id: 0, description: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {attachment_id: 0, description: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  attachment_id: 0,
  description: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"attachment_id": @0,
                              @"description": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'attachment_id' => 0,
    'description' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment', [
  'body' => '{
  "attachment_id": 0,
  "description": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment"

payload = {
    "attachment_id": 0,
    "description": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment"

payload <- "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment";

    let payload = json!({
        "attachment_id": 0,
        "description": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "attachment_id": 0,
  "description": ""
}'
echo '{
  "attachment_id": 0,
  "description": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "attachment_id": 0,\n  "description": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "attachment_id": 0,
  "description": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_NoteAttachment_for_User_MonetaryAccount_IdealMerchantTransaction
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
ideal-merchant-transactionID
BODY json

{
  "attachment_id": 0,
  "description": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment" {:headers {:user-agent ""
                                                                                                                                                                                 :x-bunq-client-authentication ""}
                                                                                                                                                                       :content-type :json
                                                                                                                                                                       :form-params {:attachment_id 0
                                                                                                                                                                                     :description ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment"

	payload := strings.NewReader("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 45

{
  "attachment_id": 0,
  "description": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  attachment_id: 0,
  description: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "attachment_id": 0,\n  "description": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({attachment_id: 0, description: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {attachment_id: 0, description: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  attachment_id: 0,
  description: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"attachment_id": @0,
                              @"description": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'attachment_id' => 0,
    'description' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment', [
  'body' => '{
  "attachment_id": 0,
  "description": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment"

payload = {
    "attachment_id": 0,
    "description": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment"

payload <- "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment";

    let payload = json!({
        "attachment_id": 0,
        "description": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "attachment_id": 0,
  "description": ""
}'
echo '{
  "attachment_id": 0,
  "description": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "attachment_id": 0,\n  "description": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "attachment_id": 0,
  "description": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_NoteAttachment_for_User_MonetaryAccount_MastercardAction
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
mastercard-actionID
BODY json

{
  "attachment_id": 0,
  "description": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment" {:headers {:user-agent ""
                                                                                                                                                               :x-bunq-client-authentication ""}
                                                                                                                                                     :content-type :json
                                                                                                                                                     :form-params {:attachment_id 0
                                                                                                                                                                   :description ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment"

	payload := strings.NewReader("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 45

{
  "attachment_id": 0,
  "description": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  attachment_id: 0,
  description: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "attachment_id": 0,\n  "description": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({attachment_id: 0, description: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {attachment_id: 0, description: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  attachment_id: 0,
  description: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"attachment_id": @0,
                              @"description": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'attachment_id' => 0,
    'description' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment', [
  'body' => '{
  "attachment_id": 0,
  "description": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment"

payload = {
    "attachment_id": 0,
    "description": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment"

payload <- "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment";

    let payload = json!({
        "attachment_id": 0,
        "description": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "attachment_id": 0,
  "description": ""
}'
echo '{
  "attachment_id": 0,
  "description": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "attachment_id": 0,\n  "description": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "attachment_id": 0,
  "description": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_NoteAttachment_for_User_MonetaryAccount_Payment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
paymentID
BODY json

{
  "attachment_id": 0,
  "description": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment" {:headers {:user-agent ""
                                                                                                                                           :x-bunq-client-authentication ""}
                                                                                                                                 :content-type :json
                                                                                                                                 :form-params {:attachment_id 0
                                                                                                                                               :description ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment"

	payload := strings.NewReader("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 45

{
  "attachment_id": 0,
  "description": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  attachment_id: 0,
  description: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "attachment_id": 0,\n  "description": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({attachment_id: 0, description: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {attachment_id: 0, description: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  attachment_id: 0,
  description: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"attachment_id": @0,
                              @"description": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'attachment_id' => 0,
    'description' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment', [
  'body' => '{
  "attachment_id": 0,
  "description": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment"

payload = {
    "attachment_id": 0,
    "description": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment"

payload <- "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment";

    let payload = json!({
        "attachment_id": 0,
        "description": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "attachment_id": 0,
  "description": ""
}'
echo '{
  "attachment_id": 0,
  "description": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "attachment_id": 0,\n  "description": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "attachment_id": 0,
  "description": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_NoteAttachment_for_User_MonetaryAccount_PaymentBatch
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
payment-batchID
BODY json

{
  "attachment_id": 0,
  "description": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment" {:headers {:user-agent ""
                                                                                                                                                       :x-bunq-client-authentication ""}
                                                                                                                                             :content-type :json
                                                                                                                                             :form-params {:attachment_id 0
                                                                                                                                                           :description ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment"

	payload := strings.NewReader("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 45

{
  "attachment_id": 0,
  "description": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  attachment_id: 0,
  description: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "attachment_id": 0,\n  "description": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({attachment_id: 0, description: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {attachment_id: 0, description: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  attachment_id: 0,
  description: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"attachment_id": @0,
                              @"description": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'attachment_id' => 0,
    'description' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment', [
  'body' => '{
  "attachment_id": 0,
  "description": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment"

payload = {
    "attachment_id": 0,
    "description": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment"

payload <- "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment";

    let payload = json!({
        "attachment_id": 0,
        "description": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "attachment_id": 0,
  "description": ""
}'
echo '{
  "attachment_id": 0,
  "description": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "attachment_id": 0,\n  "description": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "attachment_id": 0,
  "description": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_NoteAttachment_for_User_MonetaryAccount_RequestInquiry
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
request-inquiryID
BODY json

{
  "attachment_id": 0,
  "description": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment" {:headers {:user-agent ""
                                                                                                                                                           :x-bunq-client-authentication ""}
                                                                                                                                                 :content-type :json
                                                                                                                                                 :form-params {:attachment_id 0
                                                                                                                                                               :description ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment"

	payload := strings.NewReader("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 45

{
  "attachment_id": 0,
  "description": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  attachment_id: 0,
  description: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "attachment_id": 0,\n  "description": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({attachment_id: 0, description: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {attachment_id: 0, description: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  attachment_id: 0,
  description: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"attachment_id": @0,
                              @"description": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'attachment_id' => 0,
    'description' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment', [
  'body' => '{
  "attachment_id": 0,
  "description": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment"

payload = {
    "attachment_id": 0,
    "description": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment"

payload <- "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment";

    let payload = json!({
        "attachment_id": 0,
        "description": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "attachment_id": 0,
  "description": ""
}'
echo '{
  "attachment_id": 0,
  "description": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "attachment_id": 0,\n  "description": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "attachment_id": 0,
  "description": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_NoteAttachment_for_User_MonetaryAccount_RequestInquiryBatch
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
request-inquiry-batchID
BODY json

{
  "attachment_id": 0,
  "description": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment" {:headers {:user-agent ""
                                                                                                                                                                       :x-bunq-client-authentication ""}
                                                                                                                                                             :content-type :json
                                                                                                                                                             :form-params {:attachment_id 0
                                                                                                                                                                           :description ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment"

	payload := strings.NewReader("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 45

{
  "attachment_id": 0,
  "description": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  attachment_id: 0,
  description: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "attachment_id": 0,\n  "description": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({attachment_id: 0, description: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {attachment_id: 0, description: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  attachment_id: 0,
  description: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"attachment_id": @0,
                              @"description": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'attachment_id' => 0,
    'description' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment', [
  'body' => '{
  "attachment_id": 0,
  "description": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment"

payload = {
    "attachment_id": 0,
    "description": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment"

payload <- "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment";

    let payload = json!({
        "attachment_id": 0,
        "description": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "attachment_id": 0,
  "description": ""
}'
echo '{
  "attachment_id": 0,
  "description": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "attachment_id": 0,\n  "description": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "attachment_id": 0,
  "description": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_NoteAttachment_for_User_MonetaryAccount_RequestResponse
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
request-responseID
BODY json

{
  "attachment_id": 0,
  "description": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment" {:headers {:user-agent ""
                                                                                                                                                             :x-bunq-client-authentication ""}
                                                                                                                                                   :content-type :json
                                                                                                                                                   :form-params {:attachment_id 0
                                                                                                                                                                 :description ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment"

	payload := strings.NewReader("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 45

{
  "attachment_id": 0,
  "description": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  attachment_id: 0,
  description: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "attachment_id": 0,\n  "description": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({attachment_id: 0, description: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {attachment_id: 0, description: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  attachment_id: 0,
  description: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"attachment_id": @0,
                              @"description": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'attachment_id' => 0,
    'description' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment', [
  'body' => '{
  "attachment_id": 0,
  "description": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment"

payload = {
    "attachment_id": 0,
    "description": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment"

payload <- "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment";

    let payload = json!({
        "attachment_id": 0,
        "description": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "attachment_id": 0,
  "description": ""
}'
echo '{
  "attachment_id": 0,
  "description": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "attachment_id": 0,\n  "description": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "attachment_id": 0,
  "description": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_NoteAttachment_for_User_MonetaryAccount_SchedulePayment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
schedule-paymentID
BODY json

{
  "attachment_id": 0,
  "description": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment" {:headers {:user-agent ""
                                                                                                                                                             :x-bunq-client-authentication ""}
                                                                                                                                                   :content-type :json
                                                                                                                                                   :form-params {:attachment_id 0
                                                                                                                                                                 :description ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment"

	payload := strings.NewReader("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 45

{
  "attachment_id": 0,
  "description": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  attachment_id: 0,
  description: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "attachment_id": 0,\n  "description": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({attachment_id: 0, description: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {attachment_id: 0, description: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  attachment_id: 0,
  description: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"attachment_id": @0,
                              @"description": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'attachment_id' => 0,
    'description' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment', [
  'body' => '{
  "attachment_id": 0,
  "description": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment"

payload = {
    "attachment_id": 0,
    "description": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment"

payload <- "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment";

    let payload = json!({
        "attachment_id": 0,
        "description": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "attachment_id": 0,
  "description": ""
}'
echo '{
  "attachment_id": 0,
  "description": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "attachment_id": 0,\n  "description": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "attachment_id": 0,
  "description": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_NoteAttachment_for_User_MonetaryAccount_SchedulePaymentBatch
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
schedule-payment-batchID
BODY json

{
  "attachment_id": 0,
  "description": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment" {:headers {:user-agent ""
                                                                                                                                                                         :x-bunq-client-authentication ""}
                                                                                                                                                               :content-type :json
                                                                                                                                                               :form-params {:attachment_id 0
                                                                                                                                                                             :description ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment"

	payload := strings.NewReader("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 45

{
  "attachment_id": 0,
  "description": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  attachment_id: 0,
  description: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "attachment_id": 0,\n  "description": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({attachment_id: 0, description: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {attachment_id: 0, description: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  attachment_id: 0,
  description: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"attachment_id": @0,
                              @"description": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'attachment_id' => 0,
    'description' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment', [
  'body' => '{
  "attachment_id": 0,
  "description": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment"

payload = {
    "attachment_id": 0,
    "description": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment"

payload <- "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment";

    let payload = json!({
        "attachment_id": 0,
        "description": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "attachment_id": 0,
  "description": ""
}'
echo '{
  "attachment_id": 0,
  "description": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "attachment_id": 0,\n  "description": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "attachment_id": 0,
  "description": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_NoteAttachment_for_User_MonetaryAccount_Schedule_ScheduleInstance
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
scheduleID
schedule-instanceID
BODY json

{
  "attachment_id": 0,
  "description": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment" {:headers {:user-agent ""
                                                                                                                                                                                    :x-bunq-client-authentication ""}
                                                                                                                                                                          :content-type :json
                                                                                                                                                                          :form-params {:attachment_id 0
                                                                                                                                                                                        :description ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment"

	payload := strings.NewReader("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 45

{
  "attachment_id": 0,
  "description": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  attachment_id: 0,
  description: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "attachment_id": 0,\n  "description": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({attachment_id: 0, description: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {attachment_id: 0, description: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  attachment_id: 0,
  description: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"attachment_id": @0,
                              @"description": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'attachment_id' => 0,
    'description' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment', [
  'body' => '{
  "attachment_id": 0,
  "description": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment"

payload = {
    "attachment_id": 0,
    "description": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment"

payload <- "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment";

    let payload = json!({
        "attachment_id": 0,
        "description": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "attachment_id": 0,
  "description": ""
}'
echo '{
  "attachment_id": 0,
  "description": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "attachment_id": 0,\n  "description": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "attachment_id": 0,
  "description": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_NoteAttachment_for_User_MonetaryAccount_SofortMerchantTransaction
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
sofort-merchant-transactionID
BODY json

{
  "attachment_id": 0,
  "description": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment" {:headers {:user-agent ""
                                                                                                                                                                                   :x-bunq-client-authentication ""}
                                                                                                                                                                         :content-type :json
                                                                                                                                                                         :form-params {:attachment_id 0
                                                                                                                                                                                       :description ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment"

	payload := strings.NewReader("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 45

{
  "attachment_id": 0,
  "description": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  attachment_id: 0,
  description: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "attachment_id": 0,\n  "description": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({attachment_id: 0, description: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {attachment_id: 0, description: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  attachment_id: 0,
  description: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"attachment_id": @0,
                              @"description": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'attachment_id' => 0,
    'description' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment', [
  'body' => '{
  "attachment_id": 0,
  "description": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment"

payload = {
    "attachment_id": 0,
    "description": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment"

payload <- "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment";

    let payload = json!({
        "attachment_id": 0,
        "description": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "attachment_id": 0,
  "description": ""
}'
echo '{
  "attachment_id": 0,
  "description": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "attachment_id": 0,\n  "description": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "attachment_id": 0,
  "description": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_NoteAttachment_for_User_MonetaryAccount_SwitchServicePayment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
switch-service-paymentID
BODY json

{
  "attachment_id": 0,
  "description": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment" {:headers {:user-agent ""
                                                                                                                                                                         :x-bunq-client-authentication ""}
                                                                                                                                                               :content-type :json
                                                                                                                                                               :form-params {:attachment_id 0
                                                                                                                                                                             :description ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment"

	payload := strings.NewReader("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 45

{
  "attachment_id": 0,
  "description": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  attachment_id: 0,
  description: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "attachment_id": 0,\n  "description": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({attachment_id: 0, description: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {attachment_id: 0, description: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  attachment_id: 0,
  description: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"attachment_id": @0,
                              @"description": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'attachment_id' => 0,
    'description' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment', [
  'body' => '{
  "attachment_id": 0,
  "description": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment"

payload = {
    "attachment_id": 0,
    "description": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment"

payload <- "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment";

    let payload = json!({
        "attachment_id": 0,
        "description": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "attachment_id": 0,
  "description": ""
}'
echo '{
  "attachment_id": 0,
  "description": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "attachment_id": 0,\n  "description": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "attachment_id": 0,
  "description": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_NoteAttachment_for_User_MonetaryAccount_Whitelist_WhitelistResult
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
whitelistID
whitelist-resultID
BODY json

{
  "attachment_id": 0,
  "description": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment" {:headers {:user-agent ""
                                                                                                                                                                                    :x-bunq-client-authentication ""}
                                                                                                                                                                          :content-type :json
                                                                                                                                                                          :form-params {:attachment_id 0
                                                                                                                                                                                        :description ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment"

	payload := strings.NewReader("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 45

{
  "attachment_id": 0,
  "description": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  attachment_id: 0,
  description: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "attachment_id": 0,\n  "description": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({attachment_id: 0, description: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {attachment_id: 0, description: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  attachment_id: 0,
  description: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"attachment_id": @0,
                              @"description": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'attachment_id' => 0,
    'description' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment', [
  'body' => '{
  "attachment_id": 0,
  "description": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment"

payload = {
    "attachment_id": 0,
    "description": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment"

payload <- "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment";

    let payload = json!({
        "attachment_id": 0,
        "description": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "attachment_id": 0,
  "description": ""
}'
echo '{
  "attachment_id": 0,
  "description": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "attachment_id": 0,\n  "description": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "attachment_id": 0,
  "description": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_NoteAttachment_for_User_MonetaryAccount_BunqmeFundraiserResult
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
bunqme-fundraiser-resultID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                                                       :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId"]
                                                       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}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_NoteAttachment_for_User_MonetaryAccount_DraftPayment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
draft-paymentID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                                 :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId"]
                                                       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}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_NoteAttachment_for_User_MonetaryAccount_IdealMerchantTransaction
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
ideal-merchant-transactionID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                                                           :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId"]
                                                       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}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_NoteAttachment_for_User_MonetaryAccount_MastercardAction
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
mastercard-actionID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                                         :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId"]
                                                       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}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_NoteAttachment_for_User_MonetaryAccount_Payment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
paymentID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                     :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId"]
                                                       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}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_NoteAttachment_for_User_MonetaryAccount_PaymentBatch
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
payment-batchID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                                 :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId"]
                                                       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}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_NoteAttachment_for_User_MonetaryAccount_RequestInquiry
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
request-inquiryID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                                     :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId"]
                                                       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}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_NoteAttachment_for_User_MonetaryAccount_RequestInquiryBatch
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
request-inquiry-batchID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                                                 :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId"]
                                                       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}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_NoteAttachment_for_User_MonetaryAccount_RequestResponse
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
request-responseID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                                       :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId"]
                                                       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}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_NoteAttachment_for_User_MonetaryAccount_SchedulePayment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
schedule-paymentID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                                       :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId"]
                                                       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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_NoteAttachment_for_User_MonetaryAccount_SchedulePaymentBatch
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
schedule-payment-batchID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                                                   :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId"]
                                                       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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_NoteAttachment_for_User_MonetaryAccount_Schedule_ScheduleInstance
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
scheduleID
schedule-instanceID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                                                              :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId"]
                                                       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}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_NoteAttachment_for_User_MonetaryAccount_SofortMerchantTransaction
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
sofort-merchant-transactionID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                                                             :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId"]
                                                       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}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_NoteAttachment_for_User_MonetaryAccount_SwitchServicePayment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
switch-service-paymentID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                                                   :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId"]
                                                       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}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_NoteAttachment_for_User_MonetaryAccount_Whitelist_WhitelistResult
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
whitelistID
whitelist-resultID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                                                              :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId"]
                                                       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}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_NoteAttachment_for_User_MonetaryAccount_BunqmeFundraiserResult
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
bunqme-fundraiser-resultID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment" {:headers {:user-agent ""
                                                                                                                                                                            :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_NoteAttachment_for_User_MonetaryAccount_DraftPayment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
draft-paymentID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment" {:headers {:user-agent ""
                                                                                                                                                      :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_NoteAttachment_for_User_MonetaryAccount_IdealMerchantTransaction
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
ideal-merchant-transactionID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment" {:headers {:user-agent ""
                                                                                                                                                                                :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_NoteAttachment_for_User_MonetaryAccount_MastercardAction
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
mastercard-actionID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment" {:headers {:user-agent ""
                                                                                                                                                              :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_NoteAttachment_for_User_MonetaryAccount_Payment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
paymentID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment" {:headers {:user-agent ""
                                                                                                                                          :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_NoteAttachment_for_User_MonetaryAccount_PaymentBatch
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
payment-batchID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment" {:headers {:user-agent ""
                                                                                                                                                      :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_NoteAttachment_for_User_MonetaryAccount_RequestInquiry
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
request-inquiryID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment" {:headers {:user-agent ""
                                                                                                                                                          :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_NoteAttachment_for_User_MonetaryAccount_RequestInquiryBatch
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
request-inquiry-batchID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment" {:headers {:user-agent ""
                                                                                                                                                                      :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_NoteAttachment_for_User_MonetaryAccount_RequestResponse
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
request-responseID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment" {:headers {:user-agent ""
                                                                                                                                                            :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_NoteAttachment_for_User_MonetaryAccount_SchedulePayment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
schedule-paymentID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment" {:headers {:user-agent ""
                                                                                                                                                            :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_NoteAttachment_for_User_MonetaryAccount_SchedulePaymentBatch
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
schedule-payment-batchID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment" {:headers {:user-agent ""
                                                                                                                                                                        :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_NoteAttachment_for_User_MonetaryAccount_Schedule_ScheduleInstance
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
scheduleID
schedule-instanceID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment" {:headers {:user-agent ""
                                                                                                                                                                                   :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_NoteAttachment_for_User_MonetaryAccount_SofortMerchantTransaction
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
sofort-merchant-transactionID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment" {:headers {:user-agent ""
                                                                                                                                                                                  :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_NoteAttachment_for_User_MonetaryAccount_SwitchServicePayment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
switch-service-paymentID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment" {:headers {:user-agent ""
                                                                                                                                                                        :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_NoteAttachment_for_User_MonetaryAccount_Whitelist_WhitelistResult
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
whitelistID
whitelist-resultID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment" {:headers {:user-agent ""
                                                                                                                                                                                   :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_NoteAttachment_for_User_MonetaryAccount_BunqmeFundraiserResult
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
bunqme-fundraiser-resultID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                                                    :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_NoteAttachment_for_User_MonetaryAccount_DraftPayment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
draft-paymentID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                              :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_NoteAttachment_for_User_MonetaryAccount_IdealMerchantTransaction
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
ideal-merchant-transactionID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                                                        :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_NoteAttachment_for_User_MonetaryAccount_MastercardAction
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
mastercard-actionID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                                      :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_NoteAttachment_for_User_MonetaryAccount_Payment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
paymentID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                  :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_NoteAttachment_for_User_MonetaryAccount_PaymentBatch
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
payment-batchID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                              :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_NoteAttachment_for_User_MonetaryAccount_RequestInquiry
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
request-inquiryID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                                  :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_NoteAttachment_for_User_MonetaryAccount_RequestInquiryBatch
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
request-inquiry-batchID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                                              :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_NoteAttachment_for_User_MonetaryAccount_RequestResponse
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
request-responseID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                                    :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_NoteAttachment_for_User_MonetaryAccount_SchedulePayment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
schedule-paymentID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                                    :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_NoteAttachment_for_User_MonetaryAccount_SchedulePaymentBatch
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
schedule-payment-batchID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                                                :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_NoteAttachment_for_User_MonetaryAccount_Schedule_ScheduleInstance
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
scheduleID
schedule-instanceID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                                                           :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_NoteAttachment_for_User_MonetaryAccount_SofortMerchantTransaction
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
sofort-merchant-transactionID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                                                          :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_NoteAttachment_for_User_MonetaryAccount_SwitchServicePayment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
switch-service-paymentID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                                                :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_NoteAttachment_for_User_MonetaryAccount_Whitelist_WhitelistResult
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
whitelistID
whitelist-resultID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                                                           :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_NoteAttachment_for_User_MonetaryAccount_BunqmeFundraiserResult
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
bunqme-fundraiser-resultID
itemId
BODY json

{
  "attachment_id": 0,
  "description": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                                                    :x-bunq-client-authentication ""}
                                                                                                                                                                          :content-type :json
                                                                                                                                                                          :form-params {:attachment_id 0
                                                                                                                                                                                        :description ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId"

	payload := strings.NewReader("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 45

{
  "attachment_id": 0,
  "description": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  attachment_id: 0,
  description: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "attachment_id": 0,\n  "description": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({attachment_id: 0, description: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {attachment_id: 0, description: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  attachment_id: 0,
  description: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"attachment_id": @0,
                              @"description": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'attachment_id' => 0,
    'description' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId', [
  'body' => '{
  "attachment_id": 0,
  "description": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId"

payload = {
    "attachment_id": 0,
    "description": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId"

payload <- "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId";

    let payload = json!({
        "attachment_id": 0,
        "description": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "attachment_id": 0,
  "description": ""
}'
echo '{
  "attachment_id": 0,
  "description": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "attachment_id": 0,\n  "description": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "attachment_id": 0,
  "description": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_NoteAttachment_for_User_MonetaryAccount_DraftPayment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
draft-paymentID
itemId
BODY json

{
  "attachment_id": 0,
  "description": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                              :x-bunq-client-authentication ""}
                                                                                                                                                    :content-type :json
                                                                                                                                                    :form-params {:attachment_id 0
                                                                                                                                                                  :description ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId"

	payload := strings.NewReader("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 45

{
  "attachment_id": 0,
  "description": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  attachment_id: 0,
  description: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "attachment_id": 0,\n  "description": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({attachment_id: 0, description: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {attachment_id: 0, description: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  attachment_id: 0,
  description: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"attachment_id": @0,
                              @"description": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'attachment_id' => 0,
    'description' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId', [
  'body' => '{
  "attachment_id": 0,
  "description": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId"

payload = {
    "attachment_id": 0,
    "description": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId"

payload <- "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId";

    let payload = json!({
        "attachment_id": 0,
        "description": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "attachment_id": 0,
  "description": ""
}'
echo '{
  "attachment_id": 0,
  "description": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "attachment_id": 0,\n  "description": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "attachment_id": 0,
  "description": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_NoteAttachment_for_User_MonetaryAccount_IdealMerchantTransaction
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
ideal-merchant-transactionID
itemId
BODY json

{
  "attachment_id": 0,
  "description": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                                                        :x-bunq-client-authentication ""}
                                                                                                                                                                              :content-type :json
                                                                                                                                                                              :form-params {:attachment_id 0
                                                                                                                                                                                            :description ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId"

	payload := strings.NewReader("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 45

{
  "attachment_id": 0,
  "description": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  attachment_id: 0,
  description: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "attachment_id": 0,\n  "description": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({attachment_id: 0, description: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {attachment_id: 0, description: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  attachment_id: 0,
  description: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"attachment_id": @0,
                              @"description": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'attachment_id' => 0,
    'description' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId', [
  'body' => '{
  "attachment_id": 0,
  "description": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId"

payload = {
    "attachment_id": 0,
    "description": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId"

payload <- "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId";

    let payload = json!({
        "attachment_id": 0,
        "description": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "attachment_id": 0,
  "description": ""
}'
echo '{
  "attachment_id": 0,
  "description": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "attachment_id": 0,\n  "description": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "attachment_id": 0,
  "description": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_NoteAttachment_for_User_MonetaryAccount_MastercardAction
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
mastercard-actionID
itemId
BODY json

{
  "attachment_id": 0,
  "description": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                                      :x-bunq-client-authentication ""}
                                                                                                                                                            :content-type :json
                                                                                                                                                            :form-params {:attachment_id 0
                                                                                                                                                                          :description ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId"

	payload := strings.NewReader("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 45

{
  "attachment_id": 0,
  "description": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  attachment_id: 0,
  description: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "attachment_id": 0,\n  "description": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({attachment_id: 0, description: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {attachment_id: 0, description: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  attachment_id: 0,
  description: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"attachment_id": @0,
                              @"description": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'attachment_id' => 0,
    'description' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId', [
  'body' => '{
  "attachment_id": 0,
  "description": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId"

payload = {
    "attachment_id": 0,
    "description": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId"

payload <- "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId";

    let payload = json!({
        "attachment_id": 0,
        "description": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "attachment_id": 0,
  "description": ""
}'
echo '{
  "attachment_id": 0,
  "description": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "attachment_id": 0,\n  "description": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "attachment_id": 0,
  "description": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_NoteAttachment_for_User_MonetaryAccount_Payment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
paymentID
itemId
BODY json

{
  "attachment_id": 0,
  "description": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                  :x-bunq-client-authentication ""}
                                                                                                                                        :content-type :json
                                                                                                                                        :form-params {:attachment_id 0
                                                                                                                                                      :description ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId"

	payload := strings.NewReader("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 45

{
  "attachment_id": 0,
  "description": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  attachment_id: 0,
  description: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "attachment_id": 0,\n  "description": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({attachment_id: 0, description: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {attachment_id: 0, description: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  attachment_id: 0,
  description: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"attachment_id": @0,
                              @"description": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'attachment_id' => 0,
    'description' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId', [
  'body' => '{
  "attachment_id": 0,
  "description": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId"

payload = {
    "attachment_id": 0,
    "description": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId"

payload <- "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId";

    let payload = json!({
        "attachment_id": 0,
        "description": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "attachment_id": 0,
  "description": ""
}'
echo '{
  "attachment_id": 0,
  "description": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "attachment_id": 0,\n  "description": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "attachment_id": 0,
  "description": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_NoteAttachment_for_User_MonetaryAccount_PaymentBatch
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
payment-batchID
itemId
BODY json

{
  "attachment_id": 0,
  "description": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                              :x-bunq-client-authentication ""}
                                                                                                                                                    :content-type :json
                                                                                                                                                    :form-params {:attachment_id 0
                                                                                                                                                                  :description ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId"

	payload := strings.NewReader("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 45

{
  "attachment_id": 0,
  "description": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  attachment_id: 0,
  description: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "attachment_id": 0,\n  "description": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({attachment_id: 0, description: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {attachment_id: 0, description: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  attachment_id: 0,
  description: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"attachment_id": @0,
                              @"description": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'attachment_id' => 0,
    'description' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId', [
  'body' => '{
  "attachment_id": 0,
  "description": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId"

payload = {
    "attachment_id": 0,
    "description": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId"

payload <- "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId";

    let payload = json!({
        "attachment_id": 0,
        "description": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "attachment_id": 0,
  "description": ""
}'
echo '{
  "attachment_id": 0,
  "description": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "attachment_id": 0,\n  "description": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "attachment_id": 0,
  "description": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_NoteAttachment_for_User_MonetaryAccount_RequestInquiry
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
request-inquiryID
itemId
BODY json

{
  "attachment_id": 0,
  "description": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                                  :x-bunq-client-authentication ""}
                                                                                                                                                        :content-type :json
                                                                                                                                                        :form-params {:attachment_id 0
                                                                                                                                                                      :description ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId"

	payload := strings.NewReader("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 45

{
  "attachment_id": 0,
  "description": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  attachment_id: 0,
  description: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "attachment_id": 0,\n  "description": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({attachment_id: 0, description: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {attachment_id: 0, description: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  attachment_id: 0,
  description: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"attachment_id": @0,
                              @"description": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'attachment_id' => 0,
    'description' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId', [
  'body' => '{
  "attachment_id": 0,
  "description": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId"

payload = {
    "attachment_id": 0,
    "description": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId"

payload <- "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId";

    let payload = json!({
        "attachment_id": 0,
        "description": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "attachment_id": 0,
  "description": ""
}'
echo '{
  "attachment_id": 0,
  "description": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "attachment_id": 0,\n  "description": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "attachment_id": 0,
  "description": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_NoteAttachment_for_User_MonetaryAccount_RequestInquiryBatch
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
request-inquiry-batchID
itemId
BODY json

{
  "attachment_id": 0,
  "description": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                                              :x-bunq-client-authentication ""}
                                                                                                                                                                    :content-type :json
                                                                                                                                                                    :form-params {:attachment_id 0
                                                                                                                                                                                  :description ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId"

	payload := strings.NewReader("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 45

{
  "attachment_id": 0,
  "description": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  attachment_id: 0,
  description: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "attachment_id": 0,\n  "description": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({attachment_id: 0, description: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {attachment_id: 0, description: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  attachment_id: 0,
  description: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"attachment_id": @0,
                              @"description": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'attachment_id' => 0,
    'description' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId', [
  'body' => '{
  "attachment_id": 0,
  "description": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId"

payload = {
    "attachment_id": 0,
    "description": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId"

payload <- "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId";

    let payload = json!({
        "attachment_id": 0,
        "description": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "attachment_id": 0,
  "description": ""
}'
echo '{
  "attachment_id": 0,
  "description": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "attachment_id": 0,\n  "description": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "attachment_id": 0,
  "description": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_NoteAttachment_for_User_MonetaryAccount_RequestResponse
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
request-responseID
itemId
BODY json

{
  "attachment_id": 0,
  "description": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                                    :x-bunq-client-authentication ""}
                                                                                                                                                          :content-type :json
                                                                                                                                                          :form-params {:attachment_id 0
                                                                                                                                                                        :description ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId"

	payload := strings.NewReader("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 45

{
  "attachment_id": 0,
  "description": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  attachment_id: 0,
  description: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "attachment_id": 0,\n  "description": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({attachment_id: 0, description: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {attachment_id: 0, description: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  attachment_id: 0,
  description: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"attachment_id": @0,
                              @"description": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'attachment_id' => 0,
    'description' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId', [
  'body' => '{
  "attachment_id": 0,
  "description": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId"

payload = {
    "attachment_id": 0,
    "description": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId"

payload <- "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId";

    let payload = json!({
        "attachment_id": 0,
        "description": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "attachment_id": 0,
  "description": ""
}'
echo '{
  "attachment_id": 0,
  "description": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "attachment_id": 0,\n  "description": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "attachment_id": 0,
  "description": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_NoteAttachment_for_User_MonetaryAccount_SchedulePayment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
schedule-paymentID
itemId
BODY json

{
  "attachment_id": 0,
  "description": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                                    :x-bunq-client-authentication ""}
                                                                                                                                                          :content-type :json
                                                                                                                                                          :form-params {:attachment_id 0
                                                                                                                                                                        :description ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId"

	payload := strings.NewReader("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 45

{
  "attachment_id": 0,
  "description": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  attachment_id: 0,
  description: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "attachment_id": 0,\n  "description": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({attachment_id: 0, description: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {attachment_id: 0, description: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  attachment_id: 0,
  description: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"attachment_id": @0,
                              @"description": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'attachment_id' => 0,
    'description' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId', [
  'body' => '{
  "attachment_id": 0,
  "description": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId"

payload = {
    "attachment_id": 0,
    "description": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId"

payload <- "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId";

    let payload = json!({
        "attachment_id": 0,
        "description": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "attachment_id": 0,
  "description": ""
}'
echo '{
  "attachment_id": 0,
  "description": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "attachment_id": 0,\n  "description": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "attachment_id": 0,
  "description": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_NoteAttachment_for_User_MonetaryAccount_SchedulePaymentBatch
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
schedule-payment-batchID
itemId
BODY json

{
  "attachment_id": 0,
  "description": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                                                :x-bunq-client-authentication ""}
                                                                                                                                                                      :content-type :json
                                                                                                                                                                      :form-params {:attachment_id 0
                                                                                                                                                                                    :description ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId"

	payload := strings.NewReader("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 45

{
  "attachment_id": 0,
  "description": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  attachment_id: 0,
  description: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "attachment_id": 0,\n  "description": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({attachment_id: 0, description: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {attachment_id: 0, description: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  attachment_id: 0,
  description: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"attachment_id": @0,
                              @"description": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'attachment_id' => 0,
    'description' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId', [
  'body' => '{
  "attachment_id": 0,
  "description": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId"

payload = {
    "attachment_id": 0,
    "description": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId"

payload <- "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId";

    let payload = json!({
        "attachment_id": 0,
        "description": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "attachment_id": 0,
  "description": ""
}'
echo '{
  "attachment_id": 0,
  "description": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "attachment_id": 0,\n  "description": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "attachment_id": 0,
  "description": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_NoteAttachment_for_User_MonetaryAccount_Schedule_ScheduleInstance
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
scheduleID
schedule-instanceID
itemId
BODY json

{
  "attachment_id": 0,
  "description": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                                                           :x-bunq-client-authentication ""}
                                                                                                                                                                                 :content-type :json
                                                                                                                                                                                 :form-params {:attachment_id 0
                                                                                                                                                                                               :description ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId"

	payload := strings.NewReader("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 45

{
  "attachment_id": 0,
  "description": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  attachment_id: 0,
  description: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "attachment_id": 0,\n  "description": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({attachment_id: 0, description: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {attachment_id: 0, description: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  attachment_id: 0,
  description: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"attachment_id": @0,
                              @"description": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'attachment_id' => 0,
    'description' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId', [
  'body' => '{
  "attachment_id": 0,
  "description": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId"

payload = {
    "attachment_id": 0,
    "description": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId"

payload <- "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId";

    let payload = json!({
        "attachment_id": 0,
        "description": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "attachment_id": 0,
  "description": ""
}'
echo '{
  "attachment_id": 0,
  "description": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "attachment_id": 0,\n  "description": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "attachment_id": 0,
  "description": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_NoteAttachment_for_User_MonetaryAccount_SofortMerchantTransaction
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
sofort-merchant-transactionID
itemId
BODY json

{
  "attachment_id": 0,
  "description": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                                                          :x-bunq-client-authentication ""}
                                                                                                                                                                                :content-type :json
                                                                                                                                                                                :form-params {:attachment_id 0
                                                                                                                                                                                              :description ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId"

	payload := strings.NewReader("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 45

{
  "attachment_id": 0,
  "description": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  attachment_id: 0,
  description: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "attachment_id": 0,\n  "description": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({attachment_id: 0, description: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {attachment_id: 0, description: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  attachment_id: 0,
  description: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"attachment_id": @0,
                              @"description": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'attachment_id' => 0,
    'description' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId', [
  'body' => '{
  "attachment_id": 0,
  "description": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId"

payload = {
    "attachment_id": 0,
    "description": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId"

payload <- "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId";

    let payload = json!({
        "attachment_id": 0,
        "description": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "attachment_id": 0,
  "description": ""
}'
echo '{
  "attachment_id": 0,
  "description": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "attachment_id": 0,\n  "description": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "attachment_id": 0,
  "description": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_NoteAttachment_for_User_MonetaryAccount_SwitchServicePayment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
switch-service-paymentID
itemId
BODY json

{
  "attachment_id": 0,
  "description": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                                                :x-bunq-client-authentication ""}
                                                                                                                                                                      :content-type :json
                                                                                                                                                                      :form-params {:attachment_id 0
                                                                                                                                                                                    :description ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId"

	payload := strings.NewReader("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 45

{
  "attachment_id": 0,
  "description": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  attachment_id: 0,
  description: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "attachment_id": 0,\n  "description": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({attachment_id: 0, description: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {attachment_id: 0, description: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  attachment_id: 0,
  description: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"attachment_id": @0,
                              @"description": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'attachment_id' => 0,
    'description' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId', [
  'body' => '{
  "attachment_id": 0,
  "description": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId"

payload = {
    "attachment_id": 0,
    "description": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId"

payload <- "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId";

    let payload = json!({
        "attachment_id": 0,
        "description": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "attachment_id": 0,
  "description": ""
}'
echo '{
  "attachment_id": 0,
  "description": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "attachment_id": 0,\n  "description": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "attachment_id": 0,
  "description": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_NoteAttachment_for_User_MonetaryAccount_Whitelist_WhitelistResult
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
whitelistID
whitelist-resultID
itemId
BODY json

{
  "attachment_id": 0,
  "description": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId" {:headers {:user-agent ""
                                                                                                                                                                                           :x-bunq-client-authentication ""}
                                                                                                                                                                                 :content-type :json
                                                                                                                                                                                 :form-params {:attachment_id 0
                                                                                                                                                                                               :description ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId"

	payload := strings.NewReader("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 45

{
  "attachment_id": 0,
  "description": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  attachment_id: 0,
  description: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "attachment_id": 0,\n  "description": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({attachment_id: 0, description: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {attachment_id: 0, description: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  attachment_id: 0,
  description: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {attachment_id: 0, description: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"attachment_id":0,"description":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"attachment_id": @0,
                              @"description": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'attachment_id' => 0,
    'description' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId', [
  'body' => '{
  "attachment_id": 0,
  "description": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'attachment_id' => 0,
  'description' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "attachment_id": 0,
  "description": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId"

payload = {
    "attachment_id": 0,
    "description": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId"

payload <- "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"attachment_id\": 0,\n  \"description\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId";

    let payload = json!({
        "attachment_id": 0,
        "description": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "attachment_id": 0,
  "description": ""
}'
echo '{
  "attachment_id": 0,
  "description": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "attachment_id": 0,\n  "description": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "attachment_id": 0,
  "description": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-attachment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_NoteText_for_User_MonetaryAccount_BunqmeFundraiserResult
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
bunqme-fundraiser-resultID
BODY json

{
  "content": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"content\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text" {:headers {:user-agent ""
                                                                                                                                                                       :x-bunq-client-authentication ""}
                                                                                                                                                             :content-type :json
                                                                                                                                                             :form-params {:content ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"content\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"content\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"content\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text"

	payload := strings.NewReader("{\n  \"content\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 19

{
  "content": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"content\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"content\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"content\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  content: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "content": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({content: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {content: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  content: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"content": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"content\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'content' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text', [
  'body' => '{
  "content": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'content' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'content' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"content\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text"

payload = { "content": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text"

payload <- "{\n  \"content\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"content\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"content\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text";

    let payload = json!({"content": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "content": ""
}'
echo '{
  "content": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "content": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["content": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_NoteText_for_User_MonetaryAccount_DraftPayment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
draft-paymentID
BODY json

{
  "content": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"content\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text" {:headers {:user-agent ""
                                                                                                                                                 :x-bunq-client-authentication ""}
                                                                                                                                       :content-type :json
                                                                                                                                       :form-params {:content ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"content\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"content\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"content\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text"

	payload := strings.NewReader("{\n  \"content\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 19

{
  "content": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"content\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"content\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"content\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  content: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "content": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({content: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {content: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  content: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"content": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"content\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'content' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text', [
  'body' => '{
  "content": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'content' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'content' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"content\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text"

payload = { "content": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text"

payload <- "{\n  \"content\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"content\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"content\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text";

    let payload = json!({"content": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "content": ""
}'
echo '{
  "content": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "content": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["content": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_NoteText_for_User_MonetaryAccount_IdealMerchantTransaction
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
ideal-merchant-transactionID
BODY json

{
  "content": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"content\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text" {:headers {:user-agent ""
                                                                                                                                                                           :x-bunq-client-authentication ""}
                                                                                                                                                                 :content-type :json
                                                                                                                                                                 :form-params {:content ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"content\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"content\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"content\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text"

	payload := strings.NewReader("{\n  \"content\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 19

{
  "content": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"content\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"content\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"content\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  content: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "content": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({content: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {content: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  content: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"content": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"content\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'content' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text', [
  'body' => '{
  "content": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'content' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'content' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"content\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text"

payload = { "content": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text"

payload <- "{\n  \"content\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"content\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"content\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text";

    let payload = json!({"content": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "content": ""
}'
echo '{
  "content": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "content": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["content": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_NoteText_for_User_MonetaryAccount_MastercardAction
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
mastercard-actionID
BODY json

{
  "content": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"content\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text" {:headers {:user-agent ""
                                                                                                                                                         :x-bunq-client-authentication ""}
                                                                                                                                               :content-type :json
                                                                                                                                               :form-params {:content ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"content\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"content\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"content\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text"

	payload := strings.NewReader("{\n  \"content\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 19

{
  "content": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"content\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"content\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"content\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  content: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "content": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({content: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {content: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  content: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"content": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"content\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'content' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text', [
  'body' => '{
  "content": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'content' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'content' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"content\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text"

payload = { "content": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text"

payload <- "{\n  \"content\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"content\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"content\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text";

    let payload = json!({"content": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "content": ""
}'
echo '{
  "content": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "content": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["content": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_NoteText_for_User_MonetaryAccount_Payment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
paymentID
BODY json

{
  "content": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"content\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text" {:headers {:user-agent ""
                                                                                                                                     :x-bunq-client-authentication ""}
                                                                                                                           :content-type :json
                                                                                                                           :form-params {:content ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"content\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"content\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"content\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text"

	payload := strings.NewReader("{\n  \"content\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 19

{
  "content": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"content\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"content\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"content\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  content: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "content": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({content: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {content: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  content: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"content": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"content\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'content' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text', [
  'body' => '{
  "content": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'content' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'content' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"content\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text"

payload = { "content": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text"

payload <- "{\n  \"content\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"content\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"content\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text";

    let payload = json!({"content": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "content": ""
}'
echo '{
  "content": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "content": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["content": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_NoteText_for_User_MonetaryAccount_PaymentBatch
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
payment-batchID
BODY json

{
  "content": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"content\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text" {:headers {:user-agent ""
                                                                                                                                                 :x-bunq-client-authentication ""}
                                                                                                                                       :content-type :json
                                                                                                                                       :form-params {:content ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"content\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"content\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"content\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text"

	payload := strings.NewReader("{\n  \"content\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 19

{
  "content": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"content\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"content\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"content\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  content: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "content": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({content: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {content: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  content: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"content": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"content\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'content' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text', [
  'body' => '{
  "content": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'content' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'content' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"content\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text"

payload = { "content": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text"

payload <- "{\n  \"content\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"content\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"content\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text";

    let payload = json!({"content": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "content": ""
}'
echo '{
  "content": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "content": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["content": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_NoteText_for_User_MonetaryAccount_RequestInquiry
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
request-inquiryID
BODY json

{
  "content": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"content\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text" {:headers {:user-agent ""
                                                                                                                                                     :x-bunq-client-authentication ""}
                                                                                                                                           :content-type :json
                                                                                                                                           :form-params {:content ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"content\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"content\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"content\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text"

	payload := strings.NewReader("{\n  \"content\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 19

{
  "content": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"content\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"content\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"content\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  content: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "content": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({content: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {content: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  content: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"content": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"content\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'content' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text', [
  'body' => '{
  "content": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'content' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'content' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"content\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text"

payload = { "content": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text"

payload <- "{\n  \"content\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"content\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"content\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text";

    let payload = json!({"content": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "content": ""
}'
echo '{
  "content": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "content": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["content": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_NoteText_for_User_MonetaryAccount_RequestInquiryBatch
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
request-inquiry-batchID
BODY json

{
  "content": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"content\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text" {:headers {:user-agent ""
                                                                                                                                                                 :x-bunq-client-authentication ""}
                                                                                                                                                       :content-type :json
                                                                                                                                                       :form-params {:content ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"content\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"content\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"content\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text"

	payload := strings.NewReader("{\n  \"content\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 19

{
  "content": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"content\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"content\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"content\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  content: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "content": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({content: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {content: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  content: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"content": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"content\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'content' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text', [
  'body' => '{
  "content": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'content' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'content' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"content\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text"

payload = { "content": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text"

payload <- "{\n  \"content\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"content\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"content\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text";

    let payload = json!({"content": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "content": ""
}'
echo '{
  "content": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "content": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["content": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_NoteText_for_User_MonetaryAccount_RequestResponse
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
request-responseID
BODY json

{
  "content": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"content\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text" {:headers {:user-agent ""
                                                                                                                                                       :x-bunq-client-authentication ""}
                                                                                                                                             :content-type :json
                                                                                                                                             :form-params {:content ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"content\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"content\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"content\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text"

	payload := strings.NewReader("{\n  \"content\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 19

{
  "content": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"content\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"content\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"content\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  content: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "content": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({content: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {content: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  content: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"content": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"content\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'content' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text', [
  'body' => '{
  "content": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'content' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'content' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"content\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text"

payload = { "content": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text"

payload <- "{\n  \"content\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"content\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"content\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text";

    let payload = json!({"content": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "content": ""
}'
echo '{
  "content": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "content": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["content": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_NoteText_for_User_MonetaryAccount_SchedulePayment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
schedule-paymentID
BODY json

{
  "content": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"content\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text" {:headers {:user-agent ""
                                                                                                                                                       :x-bunq-client-authentication ""}
                                                                                                                                             :content-type :json
                                                                                                                                             :form-params {:content ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"content\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"content\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"content\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text"

	payload := strings.NewReader("{\n  \"content\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 19

{
  "content": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"content\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"content\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"content\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  content: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "content": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({content: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {content: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  content: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"content": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"content\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'content' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text', [
  'body' => '{
  "content": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'content' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'content' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"content\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text"

payload = { "content": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text"

payload <- "{\n  \"content\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"content\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"content\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text";

    let payload = json!({"content": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "content": ""
}'
echo '{
  "content": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "content": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["content": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_NoteText_for_User_MonetaryAccount_SchedulePaymentBatch
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
schedule-payment-batchID
BODY json

{
  "content": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"content\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text" {:headers {:user-agent ""
                                                                                                                                                                   :x-bunq-client-authentication ""}
                                                                                                                                                         :content-type :json
                                                                                                                                                         :form-params {:content ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"content\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"content\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"content\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text"

	payload := strings.NewReader("{\n  \"content\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 19

{
  "content": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"content\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"content\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"content\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  content: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "content": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({content: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {content: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  content: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"content": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"content\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'content' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text', [
  'body' => '{
  "content": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'content' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'content' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"content\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text"

payload = { "content": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text"

payload <- "{\n  \"content\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"content\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"content\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text";

    let payload = json!({"content": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "content": ""
}'
echo '{
  "content": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "content": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["content": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_NoteText_for_User_MonetaryAccount_Schedule_ScheduleInstance
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
scheduleID
schedule-instanceID
BODY json

{
  "content": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"content\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text" {:headers {:user-agent ""
                                                                                                                                                                              :x-bunq-client-authentication ""}
                                                                                                                                                                    :content-type :json
                                                                                                                                                                    :form-params {:content ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"content\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"content\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"content\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text"

	payload := strings.NewReader("{\n  \"content\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 19

{
  "content": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"content\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"content\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"content\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  content: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "content": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({content: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {content: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  content: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"content": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"content\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'content' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text', [
  'body' => '{
  "content": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'content' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'content' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"content\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text"

payload = { "content": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text"

payload <- "{\n  \"content\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"content\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"content\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text";

    let payload = json!({"content": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "content": ""
}'
echo '{
  "content": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "content": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["content": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_NoteText_for_User_MonetaryAccount_SofortMerchantTransaction
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
sofort-merchant-transactionID
BODY json

{
  "content": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"content\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text" {:headers {:user-agent ""
                                                                                                                                                                             :x-bunq-client-authentication ""}
                                                                                                                                                                   :content-type :json
                                                                                                                                                                   :form-params {:content ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"content\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"content\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"content\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text"

	payload := strings.NewReader("{\n  \"content\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 19

{
  "content": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"content\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"content\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"content\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  content: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "content": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({content: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {content: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  content: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"content": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"content\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'content' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text', [
  'body' => '{
  "content": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'content' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'content' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"content\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text"

payload = { "content": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text"

payload <- "{\n  \"content\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"content\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"content\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text";

    let payload = json!({"content": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "content": ""
}'
echo '{
  "content": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "content": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["content": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_NoteText_for_User_MonetaryAccount_SwitchServicePayment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
switch-service-paymentID
BODY json

{
  "content": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"content\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text" {:headers {:user-agent ""
                                                                                                                                                                   :x-bunq-client-authentication ""}
                                                                                                                                                         :content-type :json
                                                                                                                                                         :form-params {:content ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"content\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"content\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"content\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text"

	payload := strings.NewReader("{\n  \"content\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 19

{
  "content": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"content\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"content\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"content\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  content: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "content": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({content: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {content: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  content: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"content": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"content\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'content' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text', [
  'body' => '{
  "content": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'content' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'content' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"content\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text"

payload = { "content": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text"

payload <- "{\n  \"content\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"content\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"content\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text";

    let payload = json!({"content": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "content": ""
}'
echo '{
  "content": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "content": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["content": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_NoteText_for_User_MonetaryAccount_Whitelist_WhitelistResult
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
whitelistID
whitelist-resultID
BODY json

{
  "content": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"content\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text" {:headers {:user-agent ""
                                                                                                                                                                              :x-bunq-client-authentication ""}
                                                                                                                                                                    :content-type :json
                                                                                                                                                                    :form-params {:content ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"content\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"content\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"content\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text"

	payload := strings.NewReader("{\n  \"content\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 19

{
  "content": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"content\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"content\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"content\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  content: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "content": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({content: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {content: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  content: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"content": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"content\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'content' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text', [
  'body' => '{
  "content": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'content' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'content' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"content\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text"

payload = { "content": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text"

payload <- "{\n  \"content\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"content\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"content\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text";

    let payload = json!({"content": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "content": ""
}'
echo '{
  "content": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "content": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["content": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_NoteText_for_User_MonetaryAccount_BunqmeFundraiserResult
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
bunqme-fundraiser-resultID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                                                 :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId"]
                                                       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}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_NoteText_for_User_MonetaryAccount_DraftPayment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
draft-paymentID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                           :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId"]
                                                       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}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_NoteText_for_User_MonetaryAccount_IdealMerchantTransaction
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
ideal-merchant-transactionID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                                                     :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId"]
                                                       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}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_NoteText_for_User_MonetaryAccount_MastercardAction
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
mastercard-actionID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                                   :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId"]
                                                       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}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_NoteText_for_User_MonetaryAccount_Payment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
paymentID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                               :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId"]
                                                       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}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_NoteText_for_User_MonetaryAccount_PaymentBatch
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
payment-batchID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                           :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId"]
                                                       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}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_NoteText_for_User_MonetaryAccount_RequestInquiry
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
request-inquiryID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                               :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId"]
                                                       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}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_NoteText_for_User_MonetaryAccount_RequestInquiryBatch
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
request-inquiry-batchID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                                           :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId"]
                                                       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}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_NoteText_for_User_MonetaryAccount_RequestResponse
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
request-responseID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                                 :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId"]
                                                       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}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_NoteText_for_User_MonetaryAccount_SchedulePayment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
schedule-paymentID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                                 :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId"]
                                                       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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_NoteText_for_User_MonetaryAccount_SchedulePaymentBatch
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
schedule-payment-batchID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                                             :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId"]
                                                       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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_NoteText_for_User_MonetaryAccount_Schedule_ScheduleInstance
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
scheduleID
schedule-instanceID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                                                        :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId"]
                                                       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}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_NoteText_for_User_MonetaryAccount_SofortMerchantTransaction
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
sofort-merchant-transactionID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                                                       :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId"]
                                                       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}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_NoteText_for_User_MonetaryAccount_SwitchServicePayment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
switch-service-paymentID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                                             :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId"]
                                                       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}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_NoteText_for_User_MonetaryAccount_Whitelist_WhitelistResult
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
whitelistID
whitelist-resultID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                                                        :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId"]
                                                       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}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_NoteText_for_User_MonetaryAccount_BunqmeFundraiserResult
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
bunqme-fundraiser-resultID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text" {:headers {:user-agent ""
                                                                                                                                                                      :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_NoteText_for_User_MonetaryAccount_DraftPayment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
draft-paymentID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text" {:headers {:user-agent ""
                                                                                                                                                :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_NoteText_for_User_MonetaryAccount_IdealMerchantTransaction
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
ideal-merchant-transactionID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text" {:headers {:user-agent ""
                                                                                                                                                                          :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_NoteText_for_User_MonetaryAccount_MastercardAction
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
mastercard-actionID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text" {:headers {:user-agent ""
                                                                                                                                                        :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_NoteText_for_User_MonetaryAccount_Payment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
paymentID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text" {:headers {:user-agent ""
                                                                                                                                    :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_NoteText_for_User_MonetaryAccount_PaymentBatch
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
payment-batchID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text" {:headers {:user-agent ""
                                                                                                                                                :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_NoteText_for_User_MonetaryAccount_RequestInquiry
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
request-inquiryID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text" {:headers {:user-agent ""
                                                                                                                                                    :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_NoteText_for_User_MonetaryAccount_RequestInquiryBatch
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
request-inquiry-batchID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text" {:headers {:user-agent ""
                                                                                                                                                                :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_NoteText_for_User_MonetaryAccount_RequestResponse
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
request-responseID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text" {:headers {:user-agent ""
                                                                                                                                                      :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_NoteText_for_User_MonetaryAccount_SchedulePayment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
schedule-paymentID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text" {:headers {:user-agent ""
                                                                                                                                                      :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_NoteText_for_User_MonetaryAccount_SchedulePaymentBatch
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
schedule-payment-batchID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text" {:headers {:user-agent ""
                                                                                                                                                                  :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_NoteText_for_User_MonetaryAccount_Schedule_ScheduleInstance
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
scheduleID
schedule-instanceID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text" {:headers {:user-agent ""
                                                                                                                                                                             :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_NoteText_for_User_MonetaryAccount_SofortMerchantTransaction
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
sofort-merchant-transactionID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text" {:headers {:user-agent ""
                                                                                                                                                                            :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_NoteText_for_User_MonetaryAccount_SwitchServicePayment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
switch-service-paymentID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text" {:headers {:user-agent ""
                                                                                                                                                                  :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_NoteText_for_User_MonetaryAccount_Whitelist_WhitelistResult
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
whitelistID
whitelist-resultID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text" {:headers {:user-agent ""
                                                                                                                                                                             :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_NoteText_for_User_MonetaryAccount_BunqmeFundraiserResult
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
bunqme-fundraiser-resultID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                                              :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_NoteText_for_User_MonetaryAccount_DraftPayment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
draft-paymentID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                        :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_NoteText_for_User_MonetaryAccount_IdealMerchantTransaction
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
ideal-merchant-transactionID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                                                  :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_NoteText_for_User_MonetaryAccount_MastercardAction
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
mastercard-actionID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                                :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_NoteText_for_User_MonetaryAccount_Payment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
paymentID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                            :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_NoteText_for_User_MonetaryAccount_PaymentBatch
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
payment-batchID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                        :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_NoteText_for_User_MonetaryAccount_RequestInquiry
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
request-inquiryID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                            :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_NoteText_for_User_MonetaryAccount_RequestInquiryBatch
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
request-inquiry-batchID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                                        :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_NoteText_for_User_MonetaryAccount_RequestResponse
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
request-responseID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                              :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_NoteText_for_User_MonetaryAccount_SchedulePayment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
schedule-paymentID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                              :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_NoteText_for_User_MonetaryAccount_SchedulePaymentBatch
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
schedule-payment-batchID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                                          :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_NoteText_for_User_MonetaryAccount_Schedule_ScheduleInstance
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
scheduleID
schedule-instanceID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                                                     :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_NoteText_for_User_MonetaryAccount_SofortMerchantTransaction
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
sofort-merchant-transactionID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                                                    :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_NoteText_for_User_MonetaryAccount_SwitchServicePayment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
switch-service-paymentID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                                          :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_NoteText_for_User_MonetaryAccount_Whitelist_WhitelistResult
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
whitelistID
whitelist-resultID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                                                     :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_NoteText_for_User_MonetaryAccount_BunqmeFundraiserResult
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
bunqme-fundraiser-resultID
itemId
BODY json

{
  "content": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"content\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                                              :x-bunq-client-authentication ""}
                                                                                                                                                                    :content-type :json
                                                                                                                                                                    :form-params {:content ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"content\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"content\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"content\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId"

	payload := strings.NewReader("{\n  \"content\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 19

{
  "content": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"content\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"content\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"content\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  content: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "content": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({content: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {content: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  content: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"content": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"content\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'content' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId', [
  'body' => '{
  "content": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'content' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'content' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"content\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId"

payload = { "content": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId"

payload <- "{\n  \"content\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"content\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"content\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId";

    let payload = json!({"content": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "content": ""
}'
echo '{
  "content": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "content": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["content": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/bunqme-fundraiser-result/:bunqme-fundraiser-resultID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_NoteText_for_User_MonetaryAccount_DraftPayment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
draft-paymentID
itemId
BODY json

{
  "content": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"content\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                        :x-bunq-client-authentication ""}
                                                                                                                                              :content-type :json
                                                                                                                                              :form-params {:content ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"content\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"content\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"content\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId"

	payload := strings.NewReader("{\n  \"content\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 19

{
  "content": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"content\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"content\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"content\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  content: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "content": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({content: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {content: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  content: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"content": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"content\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'content' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId', [
  'body' => '{
  "content": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'content' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'content' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"content\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId"

payload = { "content": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId"

payload <- "{\n  \"content\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"content\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"content\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId";

    let payload = json!({"content": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "content": ""
}'
echo '{
  "content": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "content": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["content": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/draft-payment/:draft-paymentID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_NoteText_for_User_MonetaryAccount_IdealMerchantTransaction
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
ideal-merchant-transactionID
itemId
BODY json

{
  "content": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"content\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                                                  :x-bunq-client-authentication ""}
                                                                                                                                                                        :content-type :json
                                                                                                                                                                        :form-params {:content ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"content\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"content\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"content\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId"

	payload := strings.NewReader("{\n  \"content\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 19

{
  "content": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"content\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"content\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"content\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  content: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "content": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({content: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {content: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  content: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"content": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"content\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'content' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId', [
  'body' => '{
  "content": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'content' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'content' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"content\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId"

payload = { "content": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId"

payload <- "{\n  \"content\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"content\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"content\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId";

    let payload = json!({"content": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "content": ""
}'
echo '{
  "content": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "content": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["content": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/ideal-merchant-transaction/:ideal-merchant-transactionID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_NoteText_for_User_MonetaryAccount_MastercardAction
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
mastercard-actionID
itemId
BODY json

{
  "content": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"content\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                                :x-bunq-client-authentication ""}
                                                                                                                                                      :content-type :json
                                                                                                                                                      :form-params {:content ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"content\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"content\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"content\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId"

	payload := strings.NewReader("{\n  \"content\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 19

{
  "content": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"content\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"content\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"content\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  content: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "content": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({content: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {content: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  content: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"content": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"content\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'content' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId', [
  'body' => '{
  "content": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'content' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'content' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"content\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId"

payload = { "content": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId"

payload <- "{\n  \"content\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"content\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"content\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId";

    let payload = json!({"content": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "content": ""
}'
echo '{
  "content": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "content": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["content": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_NoteText_for_User_MonetaryAccount_Payment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
paymentID
itemId
BODY json

{
  "content": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"content\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                            :x-bunq-client-authentication ""}
                                                                                                                                  :content-type :json
                                                                                                                                  :form-params {:content ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"content\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"content\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"content\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId"

	payload := strings.NewReader("{\n  \"content\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 19

{
  "content": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"content\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"content\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"content\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  content: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "content": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({content: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {content: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  content: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"content": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"content\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'content' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId', [
  'body' => '{
  "content": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'content' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'content' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"content\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId"

payload = { "content": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId"

payload <- "{\n  \"content\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"content\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"content\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId";

    let payload = json!({"content": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "content": ""
}'
echo '{
  "content": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "content": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["content": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:paymentID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_NoteText_for_User_MonetaryAccount_PaymentBatch
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
payment-batchID
itemId
BODY json

{
  "content": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"content\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                        :x-bunq-client-authentication ""}
                                                                                                                                              :content-type :json
                                                                                                                                              :form-params {:content ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"content\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"content\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"content\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId"

	payload := strings.NewReader("{\n  \"content\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 19

{
  "content": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"content\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"content\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"content\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  content: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "content": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({content: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {content: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  content: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"content": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"content\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'content' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId', [
  'body' => '{
  "content": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'content' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'content' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"content\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId"

payload = { "content": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId"

payload <- "{\n  \"content\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"content\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"content\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId";

    let payload = json!({"content": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "content": ""
}'
echo '{
  "content": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "content": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["content": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:payment-batchID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_NoteText_for_User_MonetaryAccount_RequestInquiry
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
request-inquiryID
itemId
BODY json

{
  "content": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"content\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                            :x-bunq-client-authentication ""}
                                                                                                                                                  :content-type :json
                                                                                                                                                  :form-params {:content ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"content\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"content\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"content\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId"

	payload := strings.NewReader("{\n  \"content\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 19

{
  "content": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"content\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"content\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"content\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  content: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "content": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({content: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {content: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  content: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"content": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"content\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'content' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId', [
  'body' => '{
  "content": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'content' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'content' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"content\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId"

payload = { "content": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId"

payload <- "{\n  \"content\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"content\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"content\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId";

    let payload = json!({"content": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "content": ""
}'
echo '{
  "content": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "content": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["content": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:request-inquiryID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_NoteText_for_User_MonetaryAccount_RequestInquiryBatch
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
request-inquiry-batchID
itemId
BODY json

{
  "content": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"content\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                                        :x-bunq-client-authentication ""}
                                                                                                                                                              :content-type :json
                                                                                                                                                              :form-params {:content ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"content\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"content\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"content\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId"

	payload := strings.NewReader("{\n  \"content\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 19

{
  "content": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"content\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"content\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"content\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  content: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "content": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({content: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {content: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  content: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"content": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"content\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'content' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId', [
  'body' => '{
  "content": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'content' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'content' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"content\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId"

payload = { "content": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId"

payload <- "{\n  \"content\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"content\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"content\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId";

    let payload = json!({"content": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "content": ""
}'
echo '{
  "content": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "content": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["content": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:request-inquiry-batchID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_NoteText_for_User_MonetaryAccount_RequestResponse
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
request-responseID
itemId
BODY json

{
  "content": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"content\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                              :x-bunq-client-authentication ""}
                                                                                                                                                    :content-type :json
                                                                                                                                                    :form-params {:content ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"content\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"content\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"content\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId"

	payload := strings.NewReader("{\n  \"content\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 19

{
  "content": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"content\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"content\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"content\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  content: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "content": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({content: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {content: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  content: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"content": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"content\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'content' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId', [
  'body' => '{
  "content": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'content' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'content' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"content\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId"

payload = { "content": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId"

payload <- "{\n  \"content\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"content\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"content\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId";

    let payload = json!({"content": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "content": ""
}'
echo '{
  "content": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "content": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["content": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:request-responseID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_NoteText_for_User_MonetaryAccount_SchedulePayment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
schedule-paymentID
itemId
BODY json

{
  "content": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"content\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                              :x-bunq-client-authentication ""}
                                                                                                                                                    :content-type :json
                                                                                                                                                    :form-params {:content ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"content\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"content\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"content\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId"

	payload := strings.NewReader("{\n  \"content\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 19

{
  "content": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"content\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"content\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"content\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  content: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "content": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({content: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {content: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  content: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"content": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"content\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'content' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId', [
  'body' => '{
  "content": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'content' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'content' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"content\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId"

payload = { "content": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId"

payload <- "{\n  \"content\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"content\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"content\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId";

    let payload = json!({"content": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "content": ""
}'
echo '{
  "content": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "content": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["content": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:schedule-paymentID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_NoteText_for_User_MonetaryAccount_SchedulePaymentBatch
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
schedule-payment-batchID
itemId
BODY json

{
  "content": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"content\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                                          :x-bunq-client-authentication ""}
                                                                                                                                                                :content-type :json
                                                                                                                                                                :form-params {:content ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"content\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"content\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"content\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId"

	payload := strings.NewReader("{\n  \"content\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 19

{
  "content": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"content\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"content\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"content\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  content: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "content": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({content: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {content: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  content: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"content": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"content\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'content' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId', [
  'body' => '{
  "content": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'content' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'content' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"content\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId"

payload = { "content": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId"

payload <- "{\n  \"content\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"content\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"content\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId";

    let payload = json!({"content": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "content": ""
}'
echo '{
  "content": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "content": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["content": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:schedule-payment-batchID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_NoteText_for_User_MonetaryAccount_Schedule_ScheduleInstance
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
scheduleID
schedule-instanceID
itemId
BODY json

{
  "content": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"content\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                                                     :x-bunq-client-authentication ""}
                                                                                                                                                                           :content-type :json
                                                                                                                                                                           :form-params {:content ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"content\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"content\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"content\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId"

	payload := strings.NewReader("{\n  \"content\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 19

{
  "content": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"content\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"content\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"content\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  content: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "content": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({content: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {content: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  content: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"content": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"content\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'content' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId', [
  'body' => '{
  "content": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'content' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'content' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"content\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId"

payload = { "content": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId"

payload <- "{\n  \"content\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"content\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"content\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId";

    let payload = json!({"content": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "content": ""
}'
echo '{
  "content": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "content": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["content": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:schedule-instanceID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_NoteText_for_User_MonetaryAccount_SofortMerchantTransaction
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
sofort-merchant-transactionID
itemId
BODY json

{
  "content": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"content\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                                                    :x-bunq-client-authentication ""}
                                                                                                                                                                          :content-type :json
                                                                                                                                                                          :form-params {:content ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"content\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"content\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"content\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId"

	payload := strings.NewReader("{\n  \"content\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 19

{
  "content": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"content\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"content\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"content\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  content: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "content": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({content: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {content: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  content: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"content": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"content\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'content' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId', [
  'body' => '{
  "content": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'content' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'content' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"content\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId"

payload = { "content": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId"

payload <- "{\n  \"content\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"content\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"content\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId";

    let payload = json!({"content": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "content": ""
}'
echo '{
  "content": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "content": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["content": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:sofort-merchant-transactionID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_NoteText_for_User_MonetaryAccount_SwitchServicePayment
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
switch-service-paymentID
itemId
BODY json

{
  "content": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"content\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                                          :x-bunq-client-authentication ""}
                                                                                                                                                                :content-type :json
                                                                                                                                                                :form-params {:content ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"content\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"content\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"content\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId"

	payload := strings.NewReader("{\n  \"content\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 19

{
  "content": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"content\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"content\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"content\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  content: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "content": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({content: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {content: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  content: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"content": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"content\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'content' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId', [
  'body' => '{
  "content": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'content' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'content' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"content\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId"

payload = { "content": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId"

payload <- "{\n  \"content\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"content\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"content\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId";

    let payload = json!({"content": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "content": ""
}'
echo '{
  "content": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "content": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["content": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:switch-service-paymentID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_NoteText_for_User_MonetaryAccount_Whitelist_WhitelistResult
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
whitelistID
whitelist-resultID
itemId
BODY json

{
  "content": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"content\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId" {:headers {:user-agent ""
                                                                                                                                                                                     :x-bunq-client-authentication ""}
                                                                                                                                                                           :content-type :json
                                                                                                                                                                           :form-params {:content ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"content\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"content\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"content\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId"

	payload := strings.NewReader("{\n  \"content\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 19

{
  "content": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"content\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"content\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"content\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  content: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "content": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"content\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({content: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {content: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  content: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {content: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"content":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"content": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"content\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'content' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId', [
  'body' => '{
  "content": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'content' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'content' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "content": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"content\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId"

payload = { "content": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId"

payload <- "{\n  \"content\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"content\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"content\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId";

    let payload = json!({"content": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "content": ""
}'
echo '{
  "content": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "content": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["content": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist/:whitelistID/whitelist-result/:whitelist-resultID/note-text/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_NotificationFilterEmail_for_User
{{baseUrl}}/user/:userID/notification-filter-email
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
BODY json

{
  "notification_filters": []
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/notification-filter-email");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"notification_filters\": []\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/notification-filter-email" {:headers {:user-agent ""
                                                                                             :x-bunq-client-authentication ""}
                                                                                   :content-type :json
                                                                                   :form-params {:notification_filters []}})
require "http/client"

url = "{{baseUrl}}/user/:userID/notification-filter-email"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"notification_filters\": []\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/notification-filter-email"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"notification_filters\": []\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/notification-filter-email");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"notification_filters\": []\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/notification-filter-email"

	payload := strings.NewReader("{\n  \"notification_filters\": []\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/notification-filter-email HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 32

{
  "notification_filters": []
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/notification-filter-email")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"notification_filters\": []\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/notification-filter-email"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"notification_filters\": []\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"notification_filters\": []\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/notification-filter-email")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/notification-filter-email")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"notification_filters\": []\n}")
  .asString();
const data = JSON.stringify({
  notification_filters: []
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/notification-filter-email');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/notification-filter-email',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {notification_filters: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/notification-filter-email';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"notification_filters":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/notification-filter-email',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "notification_filters": []\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"notification_filters\": []\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/notification-filter-email")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/notification-filter-email',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({notification_filters: []}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/notification-filter-email',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {notification_filters: []},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/notification-filter-email');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  notification_filters: []
});

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}}/user/:userID/notification-filter-email',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {notification_filters: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/notification-filter-email';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"notification_filters":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"notification_filters": @[  ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/notification-filter-email"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/notification-filter-email" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"notification_filters\": []\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/notification-filter-email",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'notification_filters' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/notification-filter-email', [
  'body' => '{
  "notification_filters": []
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/notification-filter-email');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'notification_filters' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'notification_filters' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/notification-filter-email');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/notification-filter-email' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "notification_filters": []
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/notification-filter-email' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "notification_filters": []
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"notification_filters\": []\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/notification-filter-email", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/notification-filter-email"

payload = { "notification_filters": [] }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/notification-filter-email"

payload <- "{\n  \"notification_filters\": []\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/notification-filter-email")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"notification_filters\": []\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/notification-filter-email') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"notification_filters\": []\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/notification-filter-email";

    let payload = json!({"notification_filters": ()});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/notification-filter-email \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "notification_filters": []
}'
echo '{
  "notification_filters": []
}' |  \
  http POST {{baseUrl}}/user/:userID/notification-filter-email \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "notification_filters": []\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/notification-filter-email
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["notification_filters": []] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/notification-filter-email")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_NotificationFilterEmail_for_User
{{baseUrl}}/user/:userID/notification-filter-email
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/notification-filter-email");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/notification-filter-email" {:headers {:user-agent ""
                                                                                            :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/notification-filter-email"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/notification-filter-email"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/notification-filter-email");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/notification-filter-email"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/notification-filter-email HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/notification-filter-email")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/notification-filter-email"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/notification-filter-email")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/notification-filter-email")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/notification-filter-email');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/notification-filter-email',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/notification-filter-email';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/notification-filter-email',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/notification-filter-email")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/notification-filter-email',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/notification-filter-email',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/notification-filter-email');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/notification-filter-email',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/notification-filter-email';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/notification-filter-email"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/notification-filter-email" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/notification-filter-email",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/notification-filter-email', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/notification-filter-email');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/notification-filter-email');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/notification-filter-email' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/notification-filter-email' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/notification-filter-email", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/notification-filter-email"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/notification-filter-email"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/notification-filter-email")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/notification-filter-email') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/notification-filter-email";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/notification-filter-email \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/notification-filter-email \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/notification-filter-email
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/notification-filter-email")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_NotificationFilterPush_for_User
{{baseUrl}}/user/:userID/notification-filter-push
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
BODY json

{
  "notification_filters": []
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/notification-filter-push");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"notification_filters\": []\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/notification-filter-push" {:headers {:user-agent ""
                                                                                            :x-bunq-client-authentication ""}
                                                                                  :content-type :json
                                                                                  :form-params {:notification_filters []}})
require "http/client"

url = "{{baseUrl}}/user/:userID/notification-filter-push"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"notification_filters\": []\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/notification-filter-push"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"notification_filters\": []\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/notification-filter-push");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"notification_filters\": []\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/notification-filter-push"

	payload := strings.NewReader("{\n  \"notification_filters\": []\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/notification-filter-push HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 32

{
  "notification_filters": []
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/notification-filter-push")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"notification_filters\": []\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/notification-filter-push"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"notification_filters\": []\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"notification_filters\": []\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/notification-filter-push")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/notification-filter-push")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"notification_filters\": []\n}")
  .asString();
const data = JSON.stringify({
  notification_filters: []
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/notification-filter-push');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/notification-filter-push',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {notification_filters: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/notification-filter-push';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"notification_filters":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/notification-filter-push',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "notification_filters": []\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"notification_filters\": []\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/notification-filter-push")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/notification-filter-push',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({notification_filters: []}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/notification-filter-push',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {notification_filters: []},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/notification-filter-push');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  notification_filters: []
});

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}}/user/:userID/notification-filter-push',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {notification_filters: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/notification-filter-push';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"notification_filters":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"notification_filters": @[  ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/notification-filter-push"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/notification-filter-push" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"notification_filters\": []\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/notification-filter-push",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'notification_filters' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/notification-filter-push', [
  'body' => '{
  "notification_filters": []
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/notification-filter-push');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'notification_filters' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'notification_filters' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/notification-filter-push');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/notification-filter-push' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "notification_filters": []
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/notification-filter-push' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "notification_filters": []
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"notification_filters\": []\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/notification-filter-push", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/notification-filter-push"

payload = { "notification_filters": [] }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/notification-filter-push"

payload <- "{\n  \"notification_filters\": []\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/notification-filter-push")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"notification_filters\": []\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/notification-filter-push') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"notification_filters\": []\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/notification-filter-push";

    let payload = json!({"notification_filters": ()});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/notification-filter-push \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "notification_filters": []
}'
echo '{
  "notification_filters": []
}' |  \
  http POST {{baseUrl}}/user/:userID/notification-filter-push \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "notification_filters": []\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/notification-filter-push
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["notification_filters": []] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/notification-filter-push")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_NotificationFilterPush_for_User
{{baseUrl}}/user/:userID/notification-filter-push
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/notification-filter-push");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/notification-filter-push" {:headers {:user-agent ""
                                                                                           :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/notification-filter-push"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/notification-filter-push"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/notification-filter-push");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/notification-filter-push"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/notification-filter-push HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/notification-filter-push")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/notification-filter-push"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/notification-filter-push")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/notification-filter-push")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/notification-filter-push');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/notification-filter-push',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/notification-filter-push';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/notification-filter-push',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/notification-filter-push")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/notification-filter-push',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/notification-filter-push',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/notification-filter-push');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/notification-filter-push',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/notification-filter-push';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/notification-filter-push"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/notification-filter-push" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/notification-filter-push",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/notification-filter-push', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/notification-filter-push');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/notification-filter-push');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/notification-filter-push' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/notification-filter-push' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/notification-filter-push", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/notification-filter-push"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/notification-filter-push"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/notification-filter-push")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/notification-filter-push') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/notification-filter-push";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/notification-filter-push \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/notification-filter-push \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/notification-filter-push
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/notification-filter-push")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_NotificationFilterUrl_for_User
{{baseUrl}}/user/:userID/notification-filter-url
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
BODY json

{
  "notification_filters": []
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/notification-filter-url");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"notification_filters\": []\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/notification-filter-url" {:headers {:user-agent ""
                                                                                           :x-bunq-client-authentication ""}
                                                                                 :content-type :json
                                                                                 :form-params {:notification_filters []}})
require "http/client"

url = "{{baseUrl}}/user/:userID/notification-filter-url"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"notification_filters\": []\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/notification-filter-url"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"notification_filters\": []\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/notification-filter-url");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"notification_filters\": []\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/notification-filter-url"

	payload := strings.NewReader("{\n  \"notification_filters\": []\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/notification-filter-url HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 32

{
  "notification_filters": []
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/notification-filter-url")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"notification_filters\": []\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/notification-filter-url"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"notification_filters\": []\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"notification_filters\": []\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/notification-filter-url")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/notification-filter-url")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"notification_filters\": []\n}")
  .asString();
const data = JSON.stringify({
  notification_filters: []
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/notification-filter-url');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/notification-filter-url',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {notification_filters: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/notification-filter-url';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"notification_filters":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/notification-filter-url',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "notification_filters": []\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"notification_filters\": []\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/notification-filter-url")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/notification-filter-url',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({notification_filters: []}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/notification-filter-url',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {notification_filters: []},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/notification-filter-url');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  notification_filters: []
});

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}}/user/:userID/notification-filter-url',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {notification_filters: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/notification-filter-url';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"notification_filters":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"notification_filters": @[  ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/notification-filter-url"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/notification-filter-url" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"notification_filters\": []\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/notification-filter-url",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'notification_filters' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/notification-filter-url', [
  'body' => '{
  "notification_filters": []
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/notification-filter-url');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'notification_filters' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'notification_filters' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/notification-filter-url');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/notification-filter-url' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "notification_filters": []
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/notification-filter-url' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "notification_filters": []
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"notification_filters\": []\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/notification-filter-url", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/notification-filter-url"

payload = { "notification_filters": [] }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/notification-filter-url"

payload <- "{\n  \"notification_filters\": []\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/notification-filter-url")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"notification_filters\": []\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/notification-filter-url') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"notification_filters\": []\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/notification-filter-url";

    let payload = json!({"notification_filters": ()});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/notification-filter-url \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "notification_filters": []
}'
echo '{
  "notification_filters": []
}' |  \
  http POST {{baseUrl}}/user/:userID/notification-filter-url \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "notification_filters": []\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/notification-filter-url
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["notification_filters": []] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/notification-filter-url")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_NotificationFilterUrl_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
BODY json

{
  "notification_filters": [
    {
      "notification_filters": []
    }
  ]
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"notification_filters\": [\n    {\n      \"notification_filters\": []\n    }\n  ]\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url" {:headers {:user-agent ""
                                                                                                                                :x-bunq-client-authentication ""}
                                                                                                                      :content-type :json
                                                                                                                      :form-params {:notification_filters [{:notification_filters []}]}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"notification_filters\": [\n    {\n      \"notification_filters\": []\n    }\n  ]\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"notification_filters\": [\n    {\n      \"notification_filters\": []\n    }\n  ]\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"notification_filters\": [\n    {\n      \"notification_filters\": []\n    }\n  ]\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url"

	payload := strings.NewReader("{\n  \"notification_filters\": [\n    {\n      \"notification_filters\": []\n    }\n  ]\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/notification-filter-url HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 80

{
  "notification_filters": [
    {
      "notification_filters": []
    }
  ]
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"notification_filters\": [\n    {\n      \"notification_filters\": []\n    }\n  ]\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"notification_filters\": [\n    {\n      \"notification_filters\": []\n    }\n  ]\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"notification_filters\": [\n    {\n      \"notification_filters\": []\n    }\n  ]\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"notification_filters\": [\n    {\n      \"notification_filters\": []\n    }\n  ]\n}")
  .asString();
const data = JSON.stringify({
  notification_filters: [
    {
      notification_filters: []
    }
  ]
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {notification_filters: [{notification_filters: []}]}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"notification_filters":[{"notification_filters":[]}]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "notification_filters": [\n    {\n      "notification_filters": []\n    }\n  ]\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"notification_filters\": [\n    {\n      \"notification_filters\": []\n    }\n  ]\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/notification-filter-url',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({notification_filters: [{notification_filters: []}]}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {notification_filters: [{notification_filters: []}]},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  notification_filters: [
    {
      notification_filters: []
    }
  ]
});

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}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {notification_filters: [{notification_filters: []}]}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"notification_filters":[{"notification_filters":[]}]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"notification_filters": @[ @{ @"notification_filters": @[  ] } ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"notification_filters\": [\n    {\n      \"notification_filters\": []\n    }\n  ]\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'notification_filters' => [
        [
                'notification_filters' => [
                                
                ]
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url', [
  'body' => '{
  "notification_filters": [
    {
      "notification_filters": []
    }
  ]
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'notification_filters' => [
    [
        'notification_filters' => [
                
        ]
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'notification_filters' => [
    [
        'notification_filters' => [
                
        ]
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "notification_filters": [
    {
      "notification_filters": []
    }
  ]
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "notification_filters": [
    {
      "notification_filters": []
    }
  ]
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"notification_filters\": [\n    {\n      \"notification_filters\": []\n    }\n  ]\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/notification-filter-url", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url"

payload = { "notification_filters": [{ "notification_filters": [] }] }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url"

payload <- "{\n  \"notification_filters\": [\n    {\n      \"notification_filters\": []\n    }\n  ]\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"notification_filters\": [\n    {\n      \"notification_filters\": []\n    }\n  ]\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/notification-filter-url') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"notification_filters\": [\n    {\n      \"notification_filters\": []\n    }\n  ]\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url";

    let payload = json!({"notification_filters": (json!({"notification_filters": ()}))});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "notification_filters": [
    {
      "notification_filters": []
    }
  ]
}'
echo '{
  "notification_filters": [
    {
      "notification_filters": []
    }
  ]
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "notification_filters": [\n    {\n      "notification_filters": []\n    }\n  ]\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["notification_filters": [["notification_filters": []]]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_NotificationFilterUrl_for_User
{{baseUrl}}/user/:userID/notification-filter-url
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/notification-filter-url");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/notification-filter-url" {:headers {:user-agent ""
                                                                                          :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/notification-filter-url"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/notification-filter-url"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/notification-filter-url");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/notification-filter-url"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/notification-filter-url HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/notification-filter-url")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/notification-filter-url"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/notification-filter-url")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/notification-filter-url")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/notification-filter-url');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/notification-filter-url',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/notification-filter-url';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/notification-filter-url',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/notification-filter-url")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/notification-filter-url',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/notification-filter-url',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/notification-filter-url');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/notification-filter-url',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/notification-filter-url';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/notification-filter-url"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/notification-filter-url" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/notification-filter-url",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/notification-filter-url', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/notification-filter-url');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/notification-filter-url');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/notification-filter-url' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/notification-filter-url' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/notification-filter-url", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/notification-filter-url"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/notification-filter-url"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/notification-filter-url")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/notification-filter-url') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/notification-filter-url";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/notification-filter-url \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/notification-filter-url \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/notification-filter-url
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/notification-filter-url")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_NotificationFilterUrl_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url" {:headers {:user-agent ""
                                                                                                                               :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/notification-filter-url HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/notification-filter-url',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/notification-filter-url", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/notification-filter-url') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/notification-filter-url")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_OauthClient_for_User
{{baseUrl}}/user/:userID/oauth-client
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
BODY json

{
  "status": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/oauth-client");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"status\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/oauth-client" {:headers {:user-agent ""
                                                                                :x-bunq-client-authentication ""}
                                                                      :content-type :json
                                                                      :form-params {:status ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/oauth-client"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"status\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/oauth-client"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"status\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/oauth-client");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"status\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/oauth-client"

	payload := strings.NewReader("{\n  \"status\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/oauth-client HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 18

{
  "status": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/oauth-client")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"status\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/oauth-client"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"status\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"status\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/oauth-client")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/oauth-client")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"status\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  status: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/oauth-client');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/oauth-client',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {status: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/oauth-client';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/oauth-client',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "status": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"status\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/oauth-client")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/oauth-client',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({status: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/oauth-client',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {status: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/oauth-client');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  status: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/oauth-client',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {status: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/oauth-client';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"status": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/oauth-client"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/oauth-client" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"status\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/oauth-client",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'status' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/oauth-client', [
  'body' => '{
  "status": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/oauth-client');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'status' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'status' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/oauth-client');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/oauth-client' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "status": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/oauth-client' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "status": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"status\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/oauth-client", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/oauth-client"

payload = { "status": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/oauth-client"

payload <- "{\n  \"status\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/oauth-client")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"status\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/oauth-client') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"status\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/oauth-client";

    let payload = json!({"status": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/oauth-client \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "status": ""
}'
echo '{
  "status": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/oauth-client \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "status": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/oauth-client
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["status": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/oauth-client")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_OauthClient_for_User
{{baseUrl}}/user/:userID/oauth-client
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/oauth-client");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/oauth-client" {:headers {:user-agent ""
                                                                               :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/oauth-client"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/oauth-client"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/oauth-client");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/oauth-client"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/oauth-client HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/oauth-client")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/oauth-client"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/oauth-client")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/oauth-client")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/oauth-client');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/oauth-client',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/oauth-client';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/oauth-client',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/oauth-client")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/oauth-client',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/oauth-client',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/oauth-client');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/oauth-client',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/oauth-client';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/oauth-client"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/oauth-client" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/oauth-client",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/oauth-client', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/oauth-client');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/oauth-client');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/oauth-client' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/oauth-client' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/oauth-client", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/oauth-client"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/oauth-client"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/oauth-client")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/oauth-client') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/oauth-client";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/oauth-client \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/oauth-client \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/oauth-client
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/oauth-client")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_OauthClient_for_User
{{baseUrl}}/user/:userID/oauth-client/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/oauth-client/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/oauth-client/:itemId" {:headers {:user-agent ""
                                                                                       :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/oauth-client/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/oauth-client/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/oauth-client/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/oauth-client/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/oauth-client/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/oauth-client/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/oauth-client/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/oauth-client/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/oauth-client/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/oauth-client/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/oauth-client/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/oauth-client/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/oauth-client/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/oauth-client/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/oauth-client/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/oauth-client/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/oauth-client/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/oauth-client/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/oauth-client/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/oauth-client/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/oauth-client/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/oauth-client/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/oauth-client/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/oauth-client/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/oauth-client/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/oauth-client/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/oauth-client/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/oauth-client/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/oauth-client/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/oauth-client/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/oauth-client/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/oauth-client/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/oauth-client/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/oauth-client/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/oauth-client/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/oauth-client/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/oauth-client/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_OauthClient_for_User
{{baseUrl}}/user/:userID/oauth-client/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
BODY json

{
  "status": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/oauth-client/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"status\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/oauth-client/:itemId" {:headers {:user-agent ""
                                                                                       :x-bunq-client-authentication ""}
                                                                             :content-type :json
                                                                             :form-params {:status ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/oauth-client/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"status\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/oauth-client/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"status\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/oauth-client/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"status\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/oauth-client/:itemId"

	payload := strings.NewReader("{\n  \"status\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/oauth-client/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 18

{
  "status": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/oauth-client/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"status\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/oauth-client/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"status\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"status\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/oauth-client/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/oauth-client/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"status\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  status: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/oauth-client/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/oauth-client/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {status: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/oauth-client/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/oauth-client/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "status": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"status\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/oauth-client/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/oauth-client/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({status: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/oauth-client/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {status: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/oauth-client/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  status: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/oauth-client/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {status: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/oauth-client/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"status": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/oauth-client/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/oauth-client/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"status\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/oauth-client/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'status' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/oauth-client/:itemId', [
  'body' => '{
  "status": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/oauth-client/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'status' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'status' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/oauth-client/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/oauth-client/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "status": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/oauth-client/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "status": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"status\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/oauth-client/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/oauth-client/:itemId"

payload = { "status": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/oauth-client/:itemId"

payload <- "{\n  \"status\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/oauth-client/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"status\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/oauth-client/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"status\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/oauth-client/:itemId";

    let payload = json!({"status": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/oauth-client/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "status": ""
}'
echo '{
  "status": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/oauth-client/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "status": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/oauth-client/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["status": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/oauth-client/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_Payment_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
BODY json

{
  "address_billing": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_shipping": {},
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "allow_bunqto": false,
  "amount": {
    "currency": "",
    "value": ""
  },
  "attachment": [
    {
      "id": 0,
      "monetary_account_id": 0
    }
  ],
  "balance_after_mutation": {},
  "batch_id": 0,
  "bunqto_expiry": "",
  "bunqto_share_url": "",
  "bunqto_status": "",
  "bunqto_sub_status": "",
  "bunqto_time_responded": "",
  "counterparty_alias": {},
  "created": "",
  "description": "",
  "geolocation": {
    "altitude": 0,
    "latitude": 0,
    "longitude": 0,
    "radius": 0
  },
  "id": 0,
  "merchant_reference": "",
  "monetary_account_id": 0,
  "payment_auto_allocate_instance": {
    "created": "",
    "error_message": [],
    "id": 0,
    "payment_auto_allocate_id": 0,
    "payment_batch": {
      "payments": {
        "Payment": []
      }
    },
    "payment_id": 0,
    "status": "",
    "updated": ""
  },
  "request_reference_split_the_bill": [
    {
      "id": 0,
      "type": ""
    }
  ],
  "scheduled_id": 0,
  "sub_type": "",
  "type": "",
  "updated": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"allow_bunqto\": false,\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"attachment\": [\n    {\n      \"id\": 0,\n      \"monetary_account_id\": 0\n    }\n  ],\n  \"balance_after_mutation\": {},\n  \"batch_id\": 0,\n  \"bunqto_expiry\": \"\",\n  \"bunqto_share_url\": \"\",\n  \"bunqto_status\": \"\",\n  \"bunqto_sub_status\": \"\",\n  \"bunqto_time_responded\": \"\",\n  \"counterparty_alias\": {},\n  \"created\": \"\",\n  \"description\": \"\",\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"monetary_account_id\": 0,\n  \"payment_auto_allocate_instance\": {\n    \"created\": \"\",\n    \"error_message\": [],\n    \"id\": 0,\n    \"payment_auto_allocate_id\": 0,\n    \"payment_batch\": {\n      \"payments\": {\n        \"Payment\": []\n      }\n    },\n    \"payment_id\": 0,\n    \"status\": \"\",\n    \"updated\": \"\"\n  },\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"scheduled_id\": 0,\n  \"sub_type\": \"\",\n  \"type\": \"\",\n  \"updated\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment" {:headers {:user-agent ""
                                                                                                                :x-bunq-client-authentication ""}
                                                                                                      :content-type :json
                                                                                                      :form-params {:address_billing {:city ""
                                                                                                                                      :country ""
                                                                                                                                      :extra ""
                                                                                                                                      :house_number ""
                                                                                                                                      :is_user_address_updated false
                                                                                                                                      :mailbox_name ""
                                                                                                                                      :po_box ""
                                                                                                                                      :postal_code ""
                                                                                                                                      :province ""
                                                                                                                                      :street ""}
                                                                                                                    :address_shipping {}
                                                                                                                    :alias {:avatar {:anchor_uuid ""
                                                                                                                                     :image [{:attachment_public_uuid ""
                                                                                                                                              :content_type ""
                                                                                                                                              :height 0
                                                                                                                                              :width 0}]
                                                                                                                                     :style ""
                                                                                                                                     :uuid ""}
                                                                                                                            :bunq_me {:name ""
                                                                                                                                      :service ""
                                                                                                                                      :type ""
                                                                                                                                      :value ""}
                                                                                                                            :country ""
                                                                                                                            :display_name ""
                                                                                                                            :iban ""
                                                                                                                            :is_light false
                                                                                                                            :label_user {:avatar {}
                                                                                                                                         :country ""
                                                                                                                                         :display_name ""
                                                                                                                                         :public_nick_name ""
                                                                                                                                         :uuid ""}
                                                                                                                            :merchant_category_code ""
                                                                                                                            :swift_account_number ""
                                                                                                                            :swift_bic ""
                                                                                                                            :transferwise_account_number ""
                                                                                                                            :transferwise_bank_code ""}
                                                                                                                    :allow_bunqto false
                                                                                                                    :amount {:currency ""
                                                                                                                             :value ""}
                                                                                                                    :attachment [{:id 0
                                                                                                                                  :monetary_account_id 0}]
                                                                                                                    :balance_after_mutation {}
                                                                                                                    :batch_id 0
                                                                                                                    :bunqto_expiry ""
                                                                                                                    :bunqto_share_url ""
                                                                                                                    :bunqto_status ""
                                                                                                                    :bunqto_sub_status ""
                                                                                                                    :bunqto_time_responded ""
                                                                                                                    :counterparty_alias {}
                                                                                                                    :created ""
                                                                                                                    :description ""
                                                                                                                    :geolocation {:altitude 0
                                                                                                                                  :latitude 0
                                                                                                                                  :longitude 0
                                                                                                                                  :radius 0}
                                                                                                                    :id 0
                                                                                                                    :merchant_reference ""
                                                                                                                    :monetary_account_id 0
                                                                                                                    :payment_auto_allocate_instance {:created ""
                                                                                                                                                     :error_message []
                                                                                                                                                     :id 0
                                                                                                                                                     :payment_auto_allocate_id 0
                                                                                                                                                     :payment_batch {:payments {:Payment []}}
                                                                                                                                                     :payment_id 0
                                                                                                                                                     :status ""
                                                                                                                                                     :updated ""}
                                                                                                                    :request_reference_split_the_bill [{:id 0
                                                                                                                                                        :type ""}]
                                                                                                                    :scheduled_id 0
                                                                                                                    :sub_type ""
                                                                                                                    :type ""
                                                                                                                    :updated ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"allow_bunqto\": false,\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"attachment\": [\n    {\n      \"id\": 0,\n      \"monetary_account_id\": 0\n    }\n  ],\n  \"balance_after_mutation\": {},\n  \"batch_id\": 0,\n  \"bunqto_expiry\": \"\",\n  \"bunqto_share_url\": \"\",\n  \"bunqto_status\": \"\",\n  \"bunqto_sub_status\": \"\",\n  \"bunqto_time_responded\": \"\",\n  \"counterparty_alias\": {},\n  \"created\": \"\",\n  \"description\": \"\",\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"monetary_account_id\": 0,\n  \"payment_auto_allocate_instance\": {\n    \"created\": \"\",\n    \"error_message\": [],\n    \"id\": 0,\n    \"payment_auto_allocate_id\": 0,\n    \"payment_batch\": {\n      \"payments\": {\n        \"Payment\": []\n      }\n    },\n    \"payment_id\": 0,\n    \"status\": \"\",\n    \"updated\": \"\"\n  },\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"scheduled_id\": 0,\n  \"sub_type\": \"\",\n  \"type\": \"\",\n  \"updated\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"allow_bunqto\": false,\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"attachment\": [\n    {\n      \"id\": 0,\n      \"monetary_account_id\": 0\n    }\n  ],\n  \"balance_after_mutation\": {},\n  \"batch_id\": 0,\n  \"bunqto_expiry\": \"\",\n  \"bunqto_share_url\": \"\",\n  \"bunqto_status\": \"\",\n  \"bunqto_sub_status\": \"\",\n  \"bunqto_time_responded\": \"\",\n  \"counterparty_alias\": {},\n  \"created\": \"\",\n  \"description\": \"\",\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"monetary_account_id\": 0,\n  \"payment_auto_allocate_instance\": {\n    \"created\": \"\",\n    \"error_message\": [],\n    \"id\": 0,\n    \"payment_auto_allocate_id\": 0,\n    \"payment_batch\": {\n      \"payments\": {\n        \"Payment\": []\n      }\n    },\n    \"payment_id\": 0,\n    \"status\": \"\",\n    \"updated\": \"\"\n  },\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"scheduled_id\": 0,\n  \"sub_type\": \"\",\n  \"type\": \"\",\n  \"updated\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"allow_bunqto\": false,\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"attachment\": [\n    {\n      \"id\": 0,\n      \"monetary_account_id\": 0\n    }\n  ],\n  \"balance_after_mutation\": {},\n  \"batch_id\": 0,\n  \"bunqto_expiry\": \"\",\n  \"bunqto_share_url\": \"\",\n  \"bunqto_status\": \"\",\n  \"bunqto_sub_status\": \"\",\n  \"bunqto_time_responded\": \"\",\n  \"counterparty_alias\": {},\n  \"created\": \"\",\n  \"description\": \"\",\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"monetary_account_id\": 0,\n  \"payment_auto_allocate_instance\": {\n    \"created\": \"\",\n    \"error_message\": [],\n    \"id\": 0,\n    \"payment_auto_allocate_id\": 0,\n    \"payment_batch\": {\n      \"payments\": {\n        \"Payment\": []\n      }\n    },\n    \"payment_id\": 0,\n    \"status\": \"\",\n    \"updated\": \"\"\n  },\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"scheduled_id\": 0,\n  \"sub_type\": \"\",\n  \"type\": \"\",\n  \"updated\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment"

	payload := strings.NewReader("{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"allow_bunqto\": false,\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"attachment\": [\n    {\n      \"id\": 0,\n      \"monetary_account_id\": 0\n    }\n  ],\n  \"balance_after_mutation\": {},\n  \"batch_id\": 0,\n  \"bunqto_expiry\": \"\",\n  \"bunqto_share_url\": \"\",\n  \"bunqto_status\": \"\",\n  \"bunqto_sub_status\": \"\",\n  \"bunqto_time_responded\": \"\",\n  \"counterparty_alias\": {},\n  \"created\": \"\",\n  \"description\": \"\",\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"monetary_account_id\": 0,\n  \"payment_auto_allocate_instance\": {\n    \"created\": \"\",\n    \"error_message\": [],\n    \"id\": 0,\n    \"payment_auto_allocate_id\": 0,\n    \"payment_batch\": {\n      \"payments\": {\n        \"Payment\": []\n      }\n    },\n    \"payment_id\": 0,\n    \"status\": \"\",\n    \"updated\": \"\"\n  },\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"scheduled_id\": 0,\n  \"sub_type\": \"\",\n  \"type\": \"\",\n  \"updated\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/payment HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 2017

{
  "address_billing": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_shipping": {},
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "allow_bunqto": false,
  "amount": {
    "currency": "",
    "value": ""
  },
  "attachment": [
    {
      "id": 0,
      "monetary_account_id": 0
    }
  ],
  "balance_after_mutation": {},
  "batch_id": 0,
  "bunqto_expiry": "",
  "bunqto_share_url": "",
  "bunqto_status": "",
  "bunqto_sub_status": "",
  "bunqto_time_responded": "",
  "counterparty_alias": {},
  "created": "",
  "description": "",
  "geolocation": {
    "altitude": 0,
    "latitude": 0,
    "longitude": 0,
    "radius": 0
  },
  "id": 0,
  "merchant_reference": "",
  "monetary_account_id": 0,
  "payment_auto_allocate_instance": {
    "created": "",
    "error_message": [],
    "id": 0,
    "payment_auto_allocate_id": 0,
    "payment_batch": {
      "payments": {
        "Payment": []
      }
    },
    "payment_id": 0,
    "status": "",
    "updated": ""
  },
  "request_reference_split_the_bill": [
    {
      "id": 0,
      "type": ""
    }
  ],
  "scheduled_id": 0,
  "sub_type": "",
  "type": "",
  "updated": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"allow_bunqto\": false,\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"attachment\": [\n    {\n      \"id\": 0,\n      \"monetary_account_id\": 0\n    }\n  ],\n  \"balance_after_mutation\": {},\n  \"batch_id\": 0,\n  \"bunqto_expiry\": \"\",\n  \"bunqto_share_url\": \"\",\n  \"bunqto_status\": \"\",\n  \"bunqto_sub_status\": \"\",\n  \"bunqto_time_responded\": \"\",\n  \"counterparty_alias\": {},\n  \"created\": \"\",\n  \"description\": \"\",\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"monetary_account_id\": 0,\n  \"payment_auto_allocate_instance\": {\n    \"created\": \"\",\n    \"error_message\": [],\n    \"id\": 0,\n    \"payment_auto_allocate_id\": 0,\n    \"payment_batch\": {\n      \"payments\": {\n        \"Payment\": []\n      }\n    },\n    \"payment_id\": 0,\n    \"status\": \"\",\n    \"updated\": \"\"\n  },\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"scheduled_id\": 0,\n  \"sub_type\": \"\",\n  \"type\": \"\",\n  \"updated\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"allow_bunqto\": false,\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"attachment\": [\n    {\n      \"id\": 0,\n      \"monetary_account_id\": 0\n    }\n  ],\n  \"balance_after_mutation\": {},\n  \"batch_id\": 0,\n  \"bunqto_expiry\": \"\",\n  \"bunqto_share_url\": \"\",\n  \"bunqto_status\": \"\",\n  \"bunqto_sub_status\": \"\",\n  \"bunqto_time_responded\": \"\",\n  \"counterparty_alias\": {},\n  \"created\": \"\",\n  \"description\": \"\",\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"monetary_account_id\": 0,\n  \"payment_auto_allocate_instance\": {\n    \"created\": \"\",\n    \"error_message\": [],\n    \"id\": 0,\n    \"payment_auto_allocate_id\": 0,\n    \"payment_batch\": {\n      \"payments\": {\n        \"Payment\": []\n      }\n    },\n    \"payment_id\": 0,\n    \"status\": \"\",\n    \"updated\": \"\"\n  },\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"scheduled_id\": 0,\n  \"sub_type\": \"\",\n  \"type\": \"\",\n  \"updated\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"allow_bunqto\": false,\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"attachment\": [\n    {\n      \"id\": 0,\n      \"monetary_account_id\": 0\n    }\n  ],\n  \"balance_after_mutation\": {},\n  \"batch_id\": 0,\n  \"bunqto_expiry\": \"\",\n  \"bunqto_share_url\": \"\",\n  \"bunqto_status\": \"\",\n  \"bunqto_sub_status\": \"\",\n  \"bunqto_time_responded\": \"\",\n  \"counterparty_alias\": {},\n  \"created\": \"\",\n  \"description\": \"\",\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"monetary_account_id\": 0,\n  \"payment_auto_allocate_instance\": {\n    \"created\": \"\",\n    \"error_message\": [],\n    \"id\": 0,\n    \"payment_auto_allocate_id\": 0,\n    \"payment_batch\": {\n      \"payments\": {\n        \"Payment\": []\n      }\n    },\n    \"payment_id\": 0,\n    \"status\": \"\",\n    \"updated\": \"\"\n  },\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"scheduled_id\": 0,\n  \"sub_type\": \"\",\n  \"type\": \"\",\n  \"updated\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"allow_bunqto\": false,\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"attachment\": [\n    {\n      \"id\": 0,\n      \"monetary_account_id\": 0\n    }\n  ],\n  \"balance_after_mutation\": {},\n  \"batch_id\": 0,\n  \"bunqto_expiry\": \"\",\n  \"bunqto_share_url\": \"\",\n  \"bunqto_status\": \"\",\n  \"bunqto_sub_status\": \"\",\n  \"bunqto_time_responded\": \"\",\n  \"counterparty_alias\": {},\n  \"created\": \"\",\n  \"description\": \"\",\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"monetary_account_id\": 0,\n  \"payment_auto_allocate_instance\": {\n    \"created\": \"\",\n    \"error_message\": [],\n    \"id\": 0,\n    \"payment_auto_allocate_id\": 0,\n    \"payment_batch\": {\n      \"payments\": {\n        \"Payment\": []\n      }\n    },\n    \"payment_id\": 0,\n    \"status\": \"\",\n    \"updated\": \"\"\n  },\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"scheduled_id\": 0,\n  \"sub_type\": \"\",\n  \"type\": \"\",\n  \"updated\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  address_billing: {
    city: '',
    country: '',
    extra: '',
    house_number: '',
    is_user_address_updated: false,
    mailbox_name: '',
    po_box: '',
    postal_code: '',
    province: '',
    street: ''
  },
  address_shipping: {},
  alias: {
    avatar: {
      anchor_uuid: '',
      image: [
        {
          attachment_public_uuid: '',
          content_type: '',
          height: 0,
          width: 0
        }
      ],
      style: '',
      uuid: ''
    },
    bunq_me: {
      name: '',
      service: '',
      type: '',
      value: ''
    },
    country: '',
    display_name: '',
    iban: '',
    is_light: false,
    label_user: {
      avatar: {},
      country: '',
      display_name: '',
      public_nick_name: '',
      uuid: ''
    },
    merchant_category_code: '',
    swift_account_number: '',
    swift_bic: '',
    transferwise_account_number: '',
    transferwise_bank_code: ''
  },
  allow_bunqto: false,
  amount: {
    currency: '',
    value: ''
  },
  attachment: [
    {
      id: 0,
      monetary_account_id: 0
    }
  ],
  balance_after_mutation: {},
  batch_id: 0,
  bunqto_expiry: '',
  bunqto_share_url: '',
  bunqto_status: '',
  bunqto_sub_status: '',
  bunqto_time_responded: '',
  counterparty_alias: {},
  created: '',
  description: '',
  geolocation: {
    altitude: 0,
    latitude: 0,
    longitude: 0,
    radius: 0
  },
  id: 0,
  merchant_reference: '',
  monetary_account_id: 0,
  payment_auto_allocate_instance: {
    created: '',
    error_message: [],
    id: 0,
    payment_auto_allocate_id: 0,
    payment_batch: {
      payments: {
        Payment: []
      }
    },
    payment_id: 0,
    status: '',
    updated: ''
  },
  request_reference_split_the_bill: [
    {
      id: 0,
      type: ''
    }
  ],
  scheduled_id: 0,
  sub_type: '',
  type: '',
  updated: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    address_billing: {
      city: '',
      country: '',
      extra: '',
      house_number: '',
      is_user_address_updated: false,
      mailbox_name: '',
      po_box: '',
      postal_code: '',
      province: '',
      street: ''
    },
    address_shipping: {},
    alias: {
      avatar: {
        anchor_uuid: '',
        image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
        style: '',
        uuid: ''
      },
      bunq_me: {name: '', service: '', type: '', value: ''},
      country: '',
      display_name: '',
      iban: '',
      is_light: false,
      label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
      merchant_category_code: '',
      swift_account_number: '',
      swift_bic: '',
      transferwise_account_number: '',
      transferwise_bank_code: ''
    },
    allow_bunqto: false,
    amount: {currency: '', value: ''},
    attachment: [{id: 0, monetary_account_id: 0}],
    balance_after_mutation: {},
    batch_id: 0,
    bunqto_expiry: '',
    bunqto_share_url: '',
    bunqto_status: '',
    bunqto_sub_status: '',
    bunqto_time_responded: '',
    counterparty_alias: {},
    created: '',
    description: '',
    geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
    id: 0,
    merchant_reference: '',
    monetary_account_id: 0,
    payment_auto_allocate_instance: {
      created: '',
      error_message: [],
      id: 0,
      payment_auto_allocate_id: 0,
      payment_batch: {payments: {Payment: []}},
      payment_id: 0,
      status: '',
      updated: ''
    },
    request_reference_split_the_bill: [{id: 0, type: ''}],
    scheduled_id: 0,
    sub_type: '',
    type: '',
    updated: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"address_billing":{"city":"","country":"","extra":"","house_number":"","is_user_address_updated":false,"mailbox_name":"","po_box":"","postal_code":"","province":"","street":""},"address_shipping":{},"alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"allow_bunqto":false,"amount":{"currency":"","value":""},"attachment":[{"id":0,"monetary_account_id":0}],"balance_after_mutation":{},"batch_id":0,"bunqto_expiry":"","bunqto_share_url":"","bunqto_status":"","bunqto_sub_status":"","bunqto_time_responded":"","counterparty_alias":{},"created":"","description":"","geolocation":{"altitude":0,"latitude":0,"longitude":0,"radius":0},"id":0,"merchant_reference":"","monetary_account_id":0,"payment_auto_allocate_instance":{"created":"","error_message":[],"id":0,"payment_auto_allocate_id":0,"payment_batch":{"payments":{"Payment":[]}},"payment_id":0,"status":"","updated":""},"request_reference_split_the_bill":[{"id":0,"type":""}],"scheduled_id":0,"sub_type":"","type":"","updated":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "address_billing": {\n    "city": "",\n    "country": "",\n    "extra": "",\n    "house_number": "",\n    "is_user_address_updated": false,\n    "mailbox_name": "",\n    "po_box": "",\n    "postal_code": "",\n    "province": "",\n    "street": ""\n  },\n  "address_shipping": {},\n  "alias": {\n    "avatar": {\n      "anchor_uuid": "",\n      "image": [\n        {\n          "attachment_public_uuid": "",\n          "content_type": "",\n          "height": 0,\n          "width": 0\n        }\n      ],\n      "style": "",\n      "uuid": ""\n    },\n    "bunq_me": {\n      "name": "",\n      "service": "",\n      "type": "",\n      "value": ""\n    },\n    "country": "",\n    "display_name": "",\n    "iban": "",\n    "is_light": false,\n    "label_user": {\n      "avatar": {},\n      "country": "",\n      "display_name": "",\n      "public_nick_name": "",\n      "uuid": ""\n    },\n    "merchant_category_code": "",\n    "swift_account_number": "",\n    "swift_bic": "",\n    "transferwise_account_number": "",\n    "transferwise_bank_code": ""\n  },\n  "allow_bunqto": false,\n  "amount": {\n    "currency": "",\n    "value": ""\n  },\n  "attachment": [\n    {\n      "id": 0,\n      "monetary_account_id": 0\n    }\n  ],\n  "balance_after_mutation": {},\n  "batch_id": 0,\n  "bunqto_expiry": "",\n  "bunqto_share_url": "",\n  "bunqto_status": "",\n  "bunqto_sub_status": "",\n  "bunqto_time_responded": "",\n  "counterparty_alias": {},\n  "created": "",\n  "description": "",\n  "geolocation": {\n    "altitude": 0,\n    "latitude": 0,\n    "longitude": 0,\n    "radius": 0\n  },\n  "id": 0,\n  "merchant_reference": "",\n  "monetary_account_id": 0,\n  "payment_auto_allocate_instance": {\n    "created": "",\n    "error_message": [],\n    "id": 0,\n    "payment_auto_allocate_id": 0,\n    "payment_batch": {\n      "payments": {\n        "Payment": []\n      }\n    },\n    "payment_id": 0,\n    "status": "",\n    "updated": ""\n  },\n  "request_reference_split_the_bill": [\n    {\n      "id": 0,\n      "type": ""\n    }\n  ],\n  "scheduled_id": 0,\n  "sub_type": "",\n  "type": "",\n  "updated": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"allow_bunqto\": false,\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"attachment\": [\n    {\n      \"id\": 0,\n      \"monetary_account_id\": 0\n    }\n  ],\n  \"balance_after_mutation\": {},\n  \"batch_id\": 0,\n  \"bunqto_expiry\": \"\",\n  \"bunqto_share_url\": \"\",\n  \"bunqto_status\": \"\",\n  \"bunqto_sub_status\": \"\",\n  \"bunqto_time_responded\": \"\",\n  \"counterparty_alias\": {},\n  \"created\": \"\",\n  \"description\": \"\",\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"monetary_account_id\": 0,\n  \"payment_auto_allocate_instance\": {\n    \"created\": \"\",\n    \"error_message\": [],\n    \"id\": 0,\n    \"payment_auto_allocate_id\": 0,\n    \"payment_batch\": {\n      \"payments\": {\n        \"Payment\": []\n      }\n    },\n    \"payment_id\": 0,\n    \"status\": \"\",\n    \"updated\": \"\"\n  },\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"scheduled_id\": 0,\n  \"sub_type\": \"\",\n  \"type\": \"\",\n  \"updated\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  address_billing: {
    city: '',
    country: '',
    extra: '',
    house_number: '',
    is_user_address_updated: false,
    mailbox_name: '',
    po_box: '',
    postal_code: '',
    province: '',
    street: ''
  },
  address_shipping: {},
  alias: {
    avatar: {
      anchor_uuid: '',
      image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
      style: '',
      uuid: ''
    },
    bunq_me: {name: '', service: '', type: '', value: ''},
    country: '',
    display_name: '',
    iban: '',
    is_light: false,
    label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
    merchant_category_code: '',
    swift_account_number: '',
    swift_bic: '',
    transferwise_account_number: '',
    transferwise_bank_code: ''
  },
  allow_bunqto: false,
  amount: {currency: '', value: ''},
  attachment: [{id: 0, monetary_account_id: 0}],
  balance_after_mutation: {},
  batch_id: 0,
  bunqto_expiry: '',
  bunqto_share_url: '',
  bunqto_status: '',
  bunqto_sub_status: '',
  bunqto_time_responded: '',
  counterparty_alias: {},
  created: '',
  description: '',
  geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
  id: 0,
  merchant_reference: '',
  monetary_account_id: 0,
  payment_auto_allocate_instance: {
    created: '',
    error_message: [],
    id: 0,
    payment_auto_allocate_id: 0,
    payment_batch: {payments: {Payment: []}},
    payment_id: 0,
    status: '',
    updated: ''
  },
  request_reference_split_the_bill: [{id: 0, type: ''}],
  scheduled_id: 0,
  sub_type: '',
  type: '',
  updated: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    address_billing: {
      city: '',
      country: '',
      extra: '',
      house_number: '',
      is_user_address_updated: false,
      mailbox_name: '',
      po_box: '',
      postal_code: '',
      province: '',
      street: ''
    },
    address_shipping: {},
    alias: {
      avatar: {
        anchor_uuid: '',
        image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
        style: '',
        uuid: ''
      },
      bunq_me: {name: '', service: '', type: '', value: ''},
      country: '',
      display_name: '',
      iban: '',
      is_light: false,
      label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
      merchant_category_code: '',
      swift_account_number: '',
      swift_bic: '',
      transferwise_account_number: '',
      transferwise_bank_code: ''
    },
    allow_bunqto: false,
    amount: {currency: '', value: ''},
    attachment: [{id: 0, monetary_account_id: 0}],
    balance_after_mutation: {},
    batch_id: 0,
    bunqto_expiry: '',
    bunqto_share_url: '',
    bunqto_status: '',
    bunqto_sub_status: '',
    bunqto_time_responded: '',
    counterparty_alias: {},
    created: '',
    description: '',
    geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
    id: 0,
    merchant_reference: '',
    monetary_account_id: 0,
    payment_auto_allocate_instance: {
      created: '',
      error_message: [],
      id: 0,
      payment_auto_allocate_id: 0,
      payment_batch: {payments: {Payment: []}},
      payment_id: 0,
      status: '',
      updated: ''
    },
    request_reference_split_the_bill: [{id: 0, type: ''}],
    scheduled_id: 0,
    sub_type: '',
    type: '',
    updated: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  address_billing: {
    city: '',
    country: '',
    extra: '',
    house_number: '',
    is_user_address_updated: false,
    mailbox_name: '',
    po_box: '',
    postal_code: '',
    province: '',
    street: ''
  },
  address_shipping: {},
  alias: {
    avatar: {
      anchor_uuid: '',
      image: [
        {
          attachment_public_uuid: '',
          content_type: '',
          height: 0,
          width: 0
        }
      ],
      style: '',
      uuid: ''
    },
    bunq_me: {
      name: '',
      service: '',
      type: '',
      value: ''
    },
    country: '',
    display_name: '',
    iban: '',
    is_light: false,
    label_user: {
      avatar: {},
      country: '',
      display_name: '',
      public_nick_name: '',
      uuid: ''
    },
    merchant_category_code: '',
    swift_account_number: '',
    swift_bic: '',
    transferwise_account_number: '',
    transferwise_bank_code: ''
  },
  allow_bunqto: false,
  amount: {
    currency: '',
    value: ''
  },
  attachment: [
    {
      id: 0,
      monetary_account_id: 0
    }
  ],
  balance_after_mutation: {},
  batch_id: 0,
  bunqto_expiry: '',
  bunqto_share_url: '',
  bunqto_status: '',
  bunqto_sub_status: '',
  bunqto_time_responded: '',
  counterparty_alias: {},
  created: '',
  description: '',
  geolocation: {
    altitude: 0,
    latitude: 0,
    longitude: 0,
    radius: 0
  },
  id: 0,
  merchant_reference: '',
  monetary_account_id: 0,
  payment_auto_allocate_instance: {
    created: '',
    error_message: [],
    id: 0,
    payment_auto_allocate_id: 0,
    payment_batch: {
      payments: {
        Payment: []
      }
    },
    payment_id: 0,
    status: '',
    updated: ''
  },
  request_reference_split_the_bill: [
    {
      id: 0,
      type: ''
    }
  ],
  scheduled_id: 0,
  sub_type: '',
  type: '',
  updated: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/payment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    address_billing: {
      city: '',
      country: '',
      extra: '',
      house_number: '',
      is_user_address_updated: false,
      mailbox_name: '',
      po_box: '',
      postal_code: '',
      province: '',
      street: ''
    },
    address_shipping: {},
    alias: {
      avatar: {
        anchor_uuid: '',
        image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
        style: '',
        uuid: ''
      },
      bunq_me: {name: '', service: '', type: '', value: ''},
      country: '',
      display_name: '',
      iban: '',
      is_light: false,
      label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
      merchant_category_code: '',
      swift_account_number: '',
      swift_bic: '',
      transferwise_account_number: '',
      transferwise_bank_code: ''
    },
    allow_bunqto: false,
    amount: {currency: '', value: ''},
    attachment: [{id: 0, monetary_account_id: 0}],
    balance_after_mutation: {},
    batch_id: 0,
    bunqto_expiry: '',
    bunqto_share_url: '',
    bunqto_status: '',
    bunqto_sub_status: '',
    bunqto_time_responded: '',
    counterparty_alias: {},
    created: '',
    description: '',
    geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
    id: 0,
    merchant_reference: '',
    monetary_account_id: 0,
    payment_auto_allocate_instance: {
      created: '',
      error_message: [],
      id: 0,
      payment_auto_allocate_id: 0,
      payment_batch: {payments: {Payment: []}},
      payment_id: 0,
      status: '',
      updated: ''
    },
    request_reference_split_the_bill: [{id: 0, type: ''}],
    scheduled_id: 0,
    sub_type: '',
    type: '',
    updated: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"address_billing":{"city":"","country":"","extra":"","house_number":"","is_user_address_updated":false,"mailbox_name":"","po_box":"","postal_code":"","province":"","street":""},"address_shipping":{},"alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"allow_bunqto":false,"amount":{"currency":"","value":""},"attachment":[{"id":0,"monetary_account_id":0}],"balance_after_mutation":{},"batch_id":0,"bunqto_expiry":"","bunqto_share_url":"","bunqto_status":"","bunqto_sub_status":"","bunqto_time_responded":"","counterparty_alias":{},"created":"","description":"","geolocation":{"altitude":0,"latitude":0,"longitude":0,"radius":0},"id":0,"merchant_reference":"","monetary_account_id":0,"payment_auto_allocate_instance":{"created":"","error_message":[],"id":0,"payment_auto_allocate_id":0,"payment_batch":{"payments":{"Payment":[]}},"payment_id":0,"status":"","updated":""},"request_reference_split_the_bill":[{"id":0,"type":""}],"scheduled_id":0,"sub_type":"","type":"","updated":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"address_billing": @{ @"city": @"", @"country": @"", @"extra": @"", @"house_number": @"", @"is_user_address_updated": @NO, @"mailbox_name": @"", @"po_box": @"", @"postal_code": @"", @"province": @"", @"street": @"" },
                              @"address_shipping": @{  },
                              @"alias": @{ @"avatar": @{ @"anchor_uuid": @"", @"image": @[ @{ @"attachment_public_uuid": @"", @"content_type": @"", @"height": @0, @"width": @0 } ], @"style": @"", @"uuid": @"" }, @"bunq_me": @{ @"name": @"", @"service": @"", @"type": @"", @"value": @"" }, @"country": @"", @"display_name": @"", @"iban": @"", @"is_light": @NO, @"label_user": @{ @"avatar": @{  }, @"country": @"", @"display_name": @"", @"public_nick_name": @"", @"uuid": @"" }, @"merchant_category_code": @"", @"swift_account_number": @"", @"swift_bic": @"", @"transferwise_account_number": @"", @"transferwise_bank_code": @"" },
                              @"allow_bunqto": @NO,
                              @"amount": @{ @"currency": @"", @"value": @"" },
                              @"attachment": @[ @{ @"id": @0, @"monetary_account_id": @0 } ],
                              @"balance_after_mutation": @{  },
                              @"batch_id": @0,
                              @"bunqto_expiry": @"",
                              @"bunqto_share_url": @"",
                              @"bunqto_status": @"",
                              @"bunqto_sub_status": @"",
                              @"bunqto_time_responded": @"",
                              @"counterparty_alias": @{  },
                              @"created": @"",
                              @"description": @"",
                              @"geolocation": @{ @"altitude": @0, @"latitude": @0, @"longitude": @0, @"radius": @0 },
                              @"id": @0,
                              @"merchant_reference": @"",
                              @"monetary_account_id": @0,
                              @"payment_auto_allocate_instance": @{ @"created": @"", @"error_message": @[  ], @"id": @0, @"payment_auto_allocate_id": @0, @"payment_batch": @{ @"payments": @{ @"Payment": @[  ] } }, @"payment_id": @0, @"status": @"", @"updated": @"" },
                              @"request_reference_split_the_bill": @[ @{ @"id": @0, @"type": @"" } ],
                              @"scheduled_id": @0,
                              @"sub_type": @"",
                              @"type": @"",
                              @"updated": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"allow_bunqto\": false,\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"attachment\": [\n    {\n      \"id\": 0,\n      \"monetary_account_id\": 0\n    }\n  ],\n  \"balance_after_mutation\": {},\n  \"batch_id\": 0,\n  \"bunqto_expiry\": \"\",\n  \"bunqto_share_url\": \"\",\n  \"bunqto_status\": \"\",\n  \"bunqto_sub_status\": \"\",\n  \"bunqto_time_responded\": \"\",\n  \"counterparty_alias\": {},\n  \"created\": \"\",\n  \"description\": \"\",\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"monetary_account_id\": 0,\n  \"payment_auto_allocate_instance\": {\n    \"created\": \"\",\n    \"error_message\": [],\n    \"id\": 0,\n    \"payment_auto_allocate_id\": 0,\n    \"payment_batch\": {\n      \"payments\": {\n        \"Payment\": []\n      }\n    },\n    \"payment_id\": 0,\n    \"status\": \"\",\n    \"updated\": \"\"\n  },\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"scheduled_id\": 0,\n  \"sub_type\": \"\",\n  \"type\": \"\",\n  \"updated\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'address_billing' => [
        'city' => '',
        'country' => '',
        'extra' => '',
        'house_number' => '',
        'is_user_address_updated' => null,
        'mailbox_name' => '',
        'po_box' => '',
        'postal_code' => '',
        'province' => '',
        'street' => ''
    ],
    'address_shipping' => [
        
    ],
    'alias' => [
        'avatar' => [
                'anchor_uuid' => '',
                'image' => [
                                [
                                                                'attachment_public_uuid' => '',
                                                                'content_type' => '',
                                                                'height' => 0,
                                                                'width' => 0
                                ]
                ],
                'style' => '',
                'uuid' => ''
        ],
        'bunq_me' => [
                'name' => '',
                'service' => '',
                'type' => '',
                'value' => ''
        ],
        'country' => '',
        'display_name' => '',
        'iban' => '',
        'is_light' => null,
        'label_user' => [
                'avatar' => [
                                
                ],
                'country' => '',
                'display_name' => '',
                'public_nick_name' => '',
                'uuid' => ''
        ],
        'merchant_category_code' => '',
        'swift_account_number' => '',
        'swift_bic' => '',
        'transferwise_account_number' => '',
        'transferwise_bank_code' => ''
    ],
    'allow_bunqto' => null,
    'amount' => [
        'currency' => '',
        'value' => ''
    ],
    'attachment' => [
        [
                'id' => 0,
                'monetary_account_id' => 0
        ]
    ],
    'balance_after_mutation' => [
        
    ],
    'batch_id' => 0,
    'bunqto_expiry' => '',
    'bunqto_share_url' => '',
    'bunqto_status' => '',
    'bunqto_sub_status' => '',
    'bunqto_time_responded' => '',
    'counterparty_alias' => [
        
    ],
    'created' => '',
    'description' => '',
    'geolocation' => [
        'altitude' => 0,
        'latitude' => 0,
        'longitude' => 0,
        'radius' => 0
    ],
    'id' => 0,
    'merchant_reference' => '',
    'monetary_account_id' => 0,
    'payment_auto_allocate_instance' => [
        'created' => '',
        'error_message' => [
                
        ],
        'id' => 0,
        'payment_auto_allocate_id' => 0,
        'payment_batch' => [
                'payments' => [
                                'Payment' => [
                                                                
                                ]
                ]
        ],
        'payment_id' => 0,
        'status' => '',
        'updated' => ''
    ],
    'request_reference_split_the_bill' => [
        [
                'id' => 0,
                'type' => ''
        ]
    ],
    'scheduled_id' => 0,
    'sub_type' => '',
    'type' => '',
    'updated' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment', [
  'body' => '{
  "address_billing": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_shipping": {},
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "allow_bunqto": false,
  "amount": {
    "currency": "",
    "value": ""
  },
  "attachment": [
    {
      "id": 0,
      "monetary_account_id": 0
    }
  ],
  "balance_after_mutation": {},
  "batch_id": 0,
  "bunqto_expiry": "",
  "bunqto_share_url": "",
  "bunqto_status": "",
  "bunqto_sub_status": "",
  "bunqto_time_responded": "",
  "counterparty_alias": {},
  "created": "",
  "description": "",
  "geolocation": {
    "altitude": 0,
    "latitude": 0,
    "longitude": 0,
    "radius": 0
  },
  "id": 0,
  "merchant_reference": "",
  "monetary_account_id": 0,
  "payment_auto_allocate_instance": {
    "created": "",
    "error_message": [],
    "id": 0,
    "payment_auto_allocate_id": 0,
    "payment_batch": {
      "payments": {
        "Payment": []
      }
    },
    "payment_id": 0,
    "status": "",
    "updated": ""
  },
  "request_reference_split_the_bill": [
    {
      "id": 0,
      "type": ""
    }
  ],
  "scheduled_id": 0,
  "sub_type": "",
  "type": "",
  "updated": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'address_billing' => [
    'city' => '',
    'country' => '',
    'extra' => '',
    'house_number' => '',
    'is_user_address_updated' => null,
    'mailbox_name' => '',
    'po_box' => '',
    'postal_code' => '',
    'province' => '',
    'street' => ''
  ],
  'address_shipping' => [
    
  ],
  'alias' => [
    'avatar' => [
        'anchor_uuid' => '',
        'image' => [
                [
                                'attachment_public_uuid' => '',
                                'content_type' => '',
                                'height' => 0,
                                'width' => 0
                ]
        ],
        'style' => '',
        'uuid' => ''
    ],
    'bunq_me' => [
        'name' => '',
        'service' => '',
        'type' => '',
        'value' => ''
    ],
    'country' => '',
    'display_name' => '',
    'iban' => '',
    'is_light' => null,
    'label_user' => [
        'avatar' => [
                
        ],
        'country' => '',
        'display_name' => '',
        'public_nick_name' => '',
        'uuid' => ''
    ],
    'merchant_category_code' => '',
    'swift_account_number' => '',
    'swift_bic' => '',
    'transferwise_account_number' => '',
    'transferwise_bank_code' => ''
  ],
  'allow_bunqto' => null,
  'amount' => [
    'currency' => '',
    'value' => ''
  ],
  'attachment' => [
    [
        'id' => 0,
        'monetary_account_id' => 0
    ]
  ],
  'balance_after_mutation' => [
    
  ],
  'batch_id' => 0,
  'bunqto_expiry' => '',
  'bunqto_share_url' => '',
  'bunqto_status' => '',
  'bunqto_sub_status' => '',
  'bunqto_time_responded' => '',
  'counterparty_alias' => [
    
  ],
  'created' => '',
  'description' => '',
  'geolocation' => [
    'altitude' => 0,
    'latitude' => 0,
    'longitude' => 0,
    'radius' => 0
  ],
  'id' => 0,
  'merchant_reference' => '',
  'monetary_account_id' => 0,
  'payment_auto_allocate_instance' => [
    'created' => '',
    'error_message' => [
        
    ],
    'id' => 0,
    'payment_auto_allocate_id' => 0,
    'payment_batch' => [
        'payments' => [
                'Payment' => [
                                
                ]
        ]
    ],
    'payment_id' => 0,
    'status' => '',
    'updated' => ''
  ],
  'request_reference_split_the_bill' => [
    [
        'id' => 0,
        'type' => ''
    ]
  ],
  'scheduled_id' => 0,
  'sub_type' => '',
  'type' => '',
  'updated' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'address_billing' => [
    'city' => '',
    'country' => '',
    'extra' => '',
    'house_number' => '',
    'is_user_address_updated' => null,
    'mailbox_name' => '',
    'po_box' => '',
    'postal_code' => '',
    'province' => '',
    'street' => ''
  ],
  'address_shipping' => [
    
  ],
  'alias' => [
    'avatar' => [
        'anchor_uuid' => '',
        'image' => [
                [
                                'attachment_public_uuid' => '',
                                'content_type' => '',
                                'height' => 0,
                                'width' => 0
                ]
        ],
        'style' => '',
        'uuid' => ''
    ],
    'bunq_me' => [
        'name' => '',
        'service' => '',
        'type' => '',
        'value' => ''
    ],
    'country' => '',
    'display_name' => '',
    'iban' => '',
    'is_light' => null,
    'label_user' => [
        'avatar' => [
                
        ],
        'country' => '',
        'display_name' => '',
        'public_nick_name' => '',
        'uuid' => ''
    ],
    'merchant_category_code' => '',
    'swift_account_number' => '',
    'swift_bic' => '',
    'transferwise_account_number' => '',
    'transferwise_bank_code' => ''
  ],
  'allow_bunqto' => null,
  'amount' => [
    'currency' => '',
    'value' => ''
  ],
  'attachment' => [
    [
        'id' => 0,
        'monetary_account_id' => 0
    ]
  ],
  'balance_after_mutation' => [
    
  ],
  'batch_id' => 0,
  'bunqto_expiry' => '',
  'bunqto_share_url' => '',
  'bunqto_status' => '',
  'bunqto_sub_status' => '',
  'bunqto_time_responded' => '',
  'counterparty_alias' => [
    
  ],
  'created' => '',
  'description' => '',
  'geolocation' => [
    'altitude' => 0,
    'latitude' => 0,
    'longitude' => 0,
    'radius' => 0
  ],
  'id' => 0,
  'merchant_reference' => '',
  'monetary_account_id' => 0,
  'payment_auto_allocate_instance' => [
    'created' => '',
    'error_message' => [
        
    ],
    'id' => 0,
    'payment_auto_allocate_id' => 0,
    'payment_batch' => [
        'payments' => [
                'Payment' => [
                                
                ]
        ]
    ],
    'payment_id' => 0,
    'status' => '',
    'updated' => ''
  ],
  'request_reference_split_the_bill' => [
    [
        'id' => 0,
        'type' => ''
    ]
  ],
  'scheduled_id' => 0,
  'sub_type' => '',
  'type' => '',
  'updated' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "address_billing": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_shipping": {},
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "allow_bunqto": false,
  "amount": {
    "currency": "",
    "value": ""
  },
  "attachment": [
    {
      "id": 0,
      "monetary_account_id": 0
    }
  ],
  "balance_after_mutation": {},
  "batch_id": 0,
  "bunqto_expiry": "",
  "bunqto_share_url": "",
  "bunqto_status": "",
  "bunqto_sub_status": "",
  "bunqto_time_responded": "",
  "counterparty_alias": {},
  "created": "",
  "description": "",
  "geolocation": {
    "altitude": 0,
    "latitude": 0,
    "longitude": 0,
    "radius": 0
  },
  "id": 0,
  "merchant_reference": "",
  "monetary_account_id": 0,
  "payment_auto_allocate_instance": {
    "created": "",
    "error_message": [],
    "id": 0,
    "payment_auto_allocate_id": 0,
    "payment_batch": {
      "payments": {
        "Payment": []
      }
    },
    "payment_id": 0,
    "status": "",
    "updated": ""
  },
  "request_reference_split_the_bill": [
    {
      "id": 0,
      "type": ""
    }
  ],
  "scheduled_id": 0,
  "sub_type": "",
  "type": "",
  "updated": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "address_billing": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_shipping": {},
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "allow_bunqto": false,
  "amount": {
    "currency": "",
    "value": ""
  },
  "attachment": [
    {
      "id": 0,
      "monetary_account_id": 0
    }
  ],
  "balance_after_mutation": {},
  "batch_id": 0,
  "bunqto_expiry": "",
  "bunqto_share_url": "",
  "bunqto_status": "",
  "bunqto_sub_status": "",
  "bunqto_time_responded": "",
  "counterparty_alias": {},
  "created": "",
  "description": "",
  "geolocation": {
    "altitude": 0,
    "latitude": 0,
    "longitude": 0,
    "radius": 0
  },
  "id": 0,
  "merchant_reference": "",
  "monetary_account_id": 0,
  "payment_auto_allocate_instance": {
    "created": "",
    "error_message": [],
    "id": 0,
    "payment_auto_allocate_id": 0,
    "payment_batch": {
      "payments": {
        "Payment": []
      }
    },
    "payment_id": 0,
    "status": "",
    "updated": ""
  },
  "request_reference_split_the_bill": [
    {
      "id": 0,
      "type": ""
    }
  ],
  "scheduled_id": 0,
  "sub_type": "",
  "type": "",
  "updated": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"allow_bunqto\": false,\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"attachment\": [\n    {\n      \"id\": 0,\n      \"monetary_account_id\": 0\n    }\n  ],\n  \"balance_after_mutation\": {},\n  \"batch_id\": 0,\n  \"bunqto_expiry\": \"\",\n  \"bunqto_share_url\": \"\",\n  \"bunqto_status\": \"\",\n  \"bunqto_sub_status\": \"\",\n  \"bunqto_time_responded\": \"\",\n  \"counterparty_alias\": {},\n  \"created\": \"\",\n  \"description\": \"\",\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"monetary_account_id\": 0,\n  \"payment_auto_allocate_instance\": {\n    \"created\": \"\",\n    \"error_message\": [],\n    \"id\": 0,\n    \"payment_auto_allocate_id\": 0,\n    \"payment_batch\": {\n      \"payments\": {\n        \"Payment\": []\n      }\n    },\n    \"payment_id\": 0,\n    \"status\": \"\",\n    \"updated\": \"\"\n  },\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"scheduled_id\": 0,\n  \"sub_type\": \"\",\n  \"type\": \"\",\n  \"updated\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment"

payload = {
    "address_billing": {
        "city": "",
        "country": "",
        "extra": "",
        "house_number": "",
        "is_user_address_updated": False,
        "mailbox_name": "",
        "po_box": "",
        "postal_code": "",
        "province": "",
        "street": ""
    },
    "address_shipping": {},
    "alias": {
        "avatar": {
            "anchor_uuid": "",
            "image": [
                {
                    "attachment_public_uuid": "",
                    "content_type": "",
                    "height": 0,
                    "width": 0
                }
            ],
            "style": "",
            "uuid": ""
        },
        "bunq_me": {
            "name": "",
            "service": "",
            "type": "",
            "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": False,
        "label_user": {
            "avatar": {},
            "country": "",
            "display_name": "",
            "public_nick_name": "",
            "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
    },
    "allow_bunqto": False,
    "amount": {
        "currency": "",
        "value": ""
    },
    "attachment": [
        {
            "id": 0,
            "monetary_account_id": 0
        }
    ],
    "balance_after_mutation": {},
    "batch_id": 0,
    "bunqto_expiry": "",
    "bunqto_share_url": "",
    "bunqto_status": "",
    "bunqto_sub_status": "",
    "bunqto_time_responded": "",
    "counterparty_alias": {},
    "created": "",
    "description": "",
    "geolocation": {
        "altitude": 0,
        "latitude": 0,
        "longitude": 0,
        "radius": 0
    },
    "id": 0,
    "merchant_reference": "",
    "monetary_account_id": 0,
    "payment_auto_allocate_instance": {
        "created": "",
        "error_message": [],
        "id": 0,
        "payment_auto_allocate_id": 0,
        "payment_batch": { "payments": { "Payment": [] } },
        "payment_id": 0,
        "status": "",
        "updated": ""
    },
    "request_reference_split_the_bill": [
        {
            "id": 0,
            "type": ""
        }
    ],
    "scheduled_id": 0,
    "sub_type": "",
    "type": "",
    "updated": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment"

payload <- "{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"allow_bunqto\": false,\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"attachment\": [\n    {\n      \"id\": 0,\n      \"monetary_account_id\": 0\n    }\n  ],\n  \"balance_after_mutation\": {},\n  \"batch_id\": 0,\n  \"bunqto_expiry\": \"\",\n  \"bunqto_share_url\": \"\",\n  \"bunqto_status\": \"\",\n  \"bunqto_sub_status\": \"\",\n  \"bunqto_time_responded\": \"\",\n  \"counterparty_alias\": {},\n  \"created\": \"\",\n  \"description\": \"\",\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"monetary_account_id\": 0,\n  \"payment_auto_allocate_instance\": {\n    \"created\": \"\",\n    \"error_message\": [],\n    \"id\": 0,\n    \"payment_auto_allocate_id\": 0,\n    \"payment_batch\": {\n      \"payments\": {\n        \"Payment\": []\n      }\n    },\n    \"payment_id\": 0,\n    \"status\": \"\",\n    \"updated\": \"\"\n  },\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"scheduled_id\": 0,\n  \"sub_type\": \"\",\n  \"type\": \"\",\n  \"updated\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"allow_bunqto\": false,\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"attachment\": [\n    {\n      \"id\": 0,\n      \"monetary_account_id\": 0\n    }\n  ],\n  \"balance_after_mutation\": {},\n  \"batch_id\": 0,\n  \"bunqto_expiry\": \"\",\n  \"bunqto_share_url\": \"\",\n  \"bunqto_status\": \"\",\n  \"bunqto_sub_status\": \"\",\n  \"bunqto_time_responded\": \"\",\n  \"counterparty_alias\": {},\n  \"created\": \"\",\n  \"description\": \"\",\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"monetary_account_id\": 0,\n  \"payment_auto_allocate_instance\": {\n    \"created\": \"\",\n    \"error_message\": [],\n    \"id\": 0,\n    \"payment_auto_allocate_id\": 0,\n    \"payment_batch\": {\n      \"payments\": {\n        \"Payment\": []\n      }\n    },\n    \"payment_id\": 0,\n    \"status\": \"\",\n    \"updated\": \"\"\n  },\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"scheduled_id\": 0,\n  \"sub_type\": \"\",\n  \"type\": \"\",\n  \"updated\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"allow_bunqto\": false,\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"attachment\": [\n    {\n      \"id\": 0,\n      \"monetary_account_id\": 0\n    }\n  ],\n  \"balance_after_mutation\": {},\n  \"batch_id\": 0,\n  \"bunqto_expiry\": \"\",\n  \"bunqto_share_url\": \"\",\n  \"bunqto_status\": \"\",\n  \"bunqto_sub_status\": \"\",\n  \"bunqto_time_responded\": \"\",\n  \"counterparty_alias\": {},\n  \"created\": \"\",\n  \"description\": \"\",\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"monetary_account_id\": 0,\n  \"payment_auto_allocate_instance\": {\n    \"created\": \"\",\n    \"error_message\": [],\n    \"id\": 0,\n    \"payment_auto_allocate_id\": 0,\n    \"payment_batch\": {\n      \"payments\": {\n        \"Payment\": []\n      }\n    },\n    \"payment_id\": 0,\n    \"status\": \"\",\n    \"updated\": \"\"\n  },\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"scheduled_id\": 0,\n  \"sub_type\": \"\",\n  \"type\": \"\",\n  \"updated\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment";

    let payload = json!({
        "address_billing": json!({
            "city": "",
            "country": "",
            "extra": "",
            "house_number": "",
            "is_user_address_updated": false,
            "mailbox_name": "",
            "po_box": "",
            "postal_code": "",
            "province": "",
            "street": ""
        }),
        "address_shipping": json!({}),
        "alias": json!({
            "avatar": json!({
                "anchor_uuid": "",
                "image": (
                    json!({
                        "attachment_public_uuid": "",
                        "content_type": "",
                        "height": 0,
                        "width": 0
                    })
                ),
                "style": "",
                "uuid": ""
            }),
            "bunq_me": json!({
                "name": "",
                "service": "",
                "type": "",
                "value": ""
            }),
            "country": "",
            "display_name": "",
            "iban": "",
            "is_light": false,
            "label_user": json!({
                "avatar": json!({}),
                "country": "",
                "display_name": "",
                "public_nick_name": "",
                "uuid": ""
            }),
            "merchant_category_code": "",
            "swift_account_number": "",
            "swift_bic": "",
            "transferwise_account_number": "",
            "transferwise_bank_code": ""
        }),
        "allow_bunqto": false,
        "amount": json!({
            "currency": "",
            "value": ""
        }),
        "attachment": (
            json!({
                "id": 0,
                "monetary_account_id": 0
            })
        ),
        "balance_after_mutation": json!({}),
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": json!({}),
        "created": "",
        "description": "",
        "geolocation": json!({
            "altitude": 0,
            "latitude": 0,
            "longitude": 0,
            "radius": 0
        }),
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": json!({
            "created": "",
            "error_message": (),
            "id": 0,
            "payment_auto_allocate_id": 0,
            "payment_batch": json!({"payments": json!({"Payment": ()})}),
            "payment_id": 0,
            "status": "",
            "updated": ""
        }),
        "request_reference_split_the_bill": (
            json!({
                "id": 0,
                "type": ""
            })
        ),
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "address_billing": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_shipping": {},
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "allow_bunqto": false,
  "amount": {
    "currency": "",
    "value": ""
  },
  "attachment": [
    {
      "id": 0,
      "monetary_account_id": 0
    }
  ],
  "balance_after_mutation": {},
  "batch_id": 0,
  "bunqto_expiry": "",
  "bunqto_share_url": "",
  "bunqto_status": "",
  "bunqto_sub_status": "",
  "bunqto_time_responded": "",
  "counterparty_alias": {},
  "created": "",
  "description": "",
  "geolocation": {
    "altitude": 0,
    "latitude": 0,
    "longitude": 0,
    "radius": 0
  },
  "id": 0,
  "merchant_reference": "",
  "monetary_account_id": 0,
  "payment_auto_allocate_instance": {
    "created": "",
    "error_message": [],
    "id": 0,
    "payment_auto_allocate_id": 0,
    "payment_batch": {
      "payments": {
        "Payment": []
      }
    },
    "payment_id": 0,
    "status": "",
    "updated": ""
  },
  "request_reference_split_the_bill": [
    {
      "id": 0,
      "type": ""
    }
  ],
  "scheduled_id": 0,
  "sub_type": "",
  "type": "",
  "updated": ""
}'
echo '{
  "address_billing": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_shipping": {},
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "allow_bunqto": false,
  "amount": {
    "currency": "",
    "value": ""
  },
  "attachment": [
    {
      "id": 0,
      "monetary_account_id": 0
    }
  ],
  "balance_after_mutation": {},
  "batch_id": 0,
  "bunqto_expiry": "",
  "bunqto_share_url": "",
  "bunqto_status": "",
  "bunqto_sub_status": "",
  "bunqto_time_responded": "",
  "counterparty_alias": {},
  "created": "",
  "description": "",
  "geolocation": {
    "altitude": 0,
    "latitude": 0,
    "longitude": 0,
    "radius": 0
  },
  "id": 0,
  "merchant_reference": "",
  "monetary_account_id": 0,
  "payment_auto_allocate_instance": {
    "created": "",
    "error_message": [],
    "id": 0,
    "payment_auto_allocate_id": 0,
    "payment_batch": {
      "payments": {
        "Payment": []
      }
    },
    "payment_id": 0,
    "status": "",
    "updated": ""
  },
  "request_reference_split_the_bill": [
    {
      "id": 0,
      "type": ""
    }
  ],
  "scheduled_id": 0,
  "sub_type": "",
  "type": "",
  "updated": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "address_billing": {\n    "city": "",\n    "country": "",\n    "extra": "",\n    "house_number": "",\n    "is_user_address_updated": false,\n    "mailbox_name": "",\n    "po_box": "",\n    "postal_code": "",\n    "province": "",\n    "street": ""\n  },\n  "address_shipping": {},\n  "alias": {\n    "avatar": {\n      "anchor_uuid": "",\n      "image": [\n        {\n          "attachment_public_uuid": "",\n          "content_type": "",\n          "height": 0,\n          "width": 0\n        }\n      ],\n      "style": "",\n      "uuid": ""\n    },\n    "bunq_me": {\n      "name": "",\n      "service": "",\n      "type": "",\n      "value": ""\n    },\n    "country": "",\n    "display_name": "",\n    "iban": "",\n    "is_light": false,\n    "label_user": {\n      "avatar": {},\n      "country": "",\n      "display_name": "",\n      "public_nick_name": "",\n      "uuid": ""\n    },\n    "merchant_category_code": "",\n    "swift_account_number": "",\n    "swift_bic": "",\n    "transferwise_account_number": "",\n    "transferwise_bank_code": ""\n  },\n  "allow_bunqto": false,\n  "amount": {\n    "currency": "",\n    "value": ""\n  },\n  "attachment": [\n    {\n      "id": 0,\n      "monetary_account_id": 0\n    }\n  ],\n  "balance_after_mutation": {},\n  "batch_id": 0,\n  "bunqto_expiry": "",\n  "bunqto_share_url": "",\n  "bunqto_status": "",\n  "bunqto_sub_status": "",\n  "bunqto_time_responded": "",\n  "counterparty_alias": {},\n  "created": "",\n  "description": "",\n  "geolocation": {\n    "altitude": 0,\n    "latitude": 0,\n    "longitude": 0,\n    "radius": 0\n  },\n  "id": 0,\n  "merchant_reference": "",\n  "monetary_account_id": 0,\n  "payment_auto_allocate_instance": {\n    "created": "",\n    "error_message": [],\n    "id": 0,\n    "payment_auto_allocate_id": 0,\n    "payment_batch": {\n      "payments": {\n        "Payment": []\n      }\n    },\n    "payment_id": 0,\n    "status": "",\n    "updated": ""\n  },\n  "request_reference_split_the_bill": [\n    {\n      "id": 0,\n      "type": ""\n    }\n  ],\n  "scheduled_id": 0,\n  "sub_type": "",\n  "type": "",\n  "updated": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "address_billing": [
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  ],
  "address_shipping": [],
  "alias": [
    "avatar": [
      "anchor_uuid": "",
      "image": [
        [
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        ]
      ],
      "style": "",
      "uuid": ""
    ],
    "bunq_me": [
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    ],
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": [
      "avatar": [],
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    ],
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  ],
  "allow_bunqto": false,
  "amount": [
    "currency": "",
    "value": ""
  ],
  "attachment": [
    [
      "id": 0,
      "monetary_account_id": 0
    ]
  ],
  "balance_after_mutation": [],
  "batch_id": 0,
  "bunqto_expiry": "",
  "bunqto_share_url": "",
  "bunqto_status": "",
  "bunqto_sub_status": "",
  "bunqto_time_responded": "",
  "counterparty_alias": [],
  "created": "",
  "description": "",
  "geolocation": [
    "altitude": 0,
    "latitude": 0,
    "longitude": 0,
    "radius": 0
  ],
  "id": 0,
  "merchant_reference": "",
  "monetary_account_id": 0,
  "payment_auto_allocate_instance": [
    "created": "",
    "error_message": [],
    "id": 0,
    "payment_auto_allocate_id": 0,
    "payment_batch": ["payments": ["Payment": []]],
    "payment_id": 0,
    "status": "",
    "updated": ""
  ],
  "request_reference_split_the_bill": [
    [
      "id": 0,
      "type": ""
    ]
  ],
  "scheduled_id": 0,
  "sub_type": "",
  "type": "",
  "updated": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_Payment_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment" {:headers {:user-agent ""
                                                                                                               :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/payment HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_Payment_for_User_MonetaryAccount_MastercardAction
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/payment
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
mastercard-actionID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/payment");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/payment" {:headers {:user-agent ""
                                                                                                                                                      :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/payment"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/payment"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/payment");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/payment"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/payment HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/payment")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/payment"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/payment")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/payment")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/payment');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/payment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/payment';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/payment',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/payment")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/payment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/payment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/payment');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/payment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/payment';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/payment"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/payment" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/payment",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/payment', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/payment');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/payment');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/payment' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/payment' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/payment", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/payment"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/payment"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/payment")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/payment') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/payment";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/payment \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/payment \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/payment
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/mastercard-action/:mastercard-actionID/payment")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_Payment_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:itemId" {:headers {:user-agent ""
                                                                                                                       :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_PaymentAutoAllocate_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
BODY json

{
  "definition": [
    {
      "amount": {
        "currency": "",
        "value": ""
      },
      "counterparty_alias": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "created": "",
      "description": "",
      "fraction": 0,
      "id": 0,
      "type": "",
      "updated": ""
    }
  ],
  "payment_id": 0,
  "type": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"definition\": [\n    {\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"counterparty_alias\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"created\": \"\",\n      \"description\": \"\",\n      \"fraction\": 0,\n      \"id\": 0,\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"payment_id\": 0,\n  \"type\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate" {:headers {:user-agent ""
                                                                                                                              :x-bunq-client-authentication ""}
                                                                                                                    :content-type :json
                                                                                                                    :form-params {:definition [{:amount {:currency ""
                                                                                                                                                         :value ""}
                                                                                                                                                :counterparty_alias {:name ""
                                                                                                                                                                     :service ""
                                                                                                                                                                     :type ""
                                                                                                                                                                     :value ""}
                                                                                                                                                :created ""
                                                                                                                                                :description ""
                                                                                                                                                :fraction 0
                                                                                                                                                :id 0
                                                                                                                                                :type ""
                                                                                                                                                :updated ""}]
                                                                                                                                  :payment_id 0
                                                                                                                                  :type ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"definition\": [\n    {\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"counterparty_alias\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"created\": \"\",\n      \"description\": \"\",\n      \"fraction\": 0,\n      \"id\": 0,\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"payment_id\": 0,\n  \"type\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"definition\": [\n    {\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"counterparty_alias\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"created\": \"\",\n      \"description\": \"\",\n      \"fraction\": 0,\n      \"id\": 0,\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"payment_id\": 0,\n  \"type\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"definition\": [\n    {\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"counterparty_alias\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"created\": \"\",\n      \"description\": \"\",\n      \"fraction\": 0,\n      \"id\": 0,\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"payment_id\": 0,\n  \"type\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate"

	payload := strings.NewReader("{\n  \"definition\": [\n    {\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"counterparty_alias\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"created\": \"\",\n      \"description\": \"\",\n      \"fraction\": 0,\n      \"id\": 0,\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"payment_id\": 0,\n  \"type\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 383

{
  "definition": [
    {
      "amount": {
        "currency": "",
        "value": ""
      },
      "counterparty_alias": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "created": "",
      "description": "",
      "fraction": 0,
      "id": 0,
      "type": "",
      "updated": ""
    }
  ],
  "payment_id": 0,
  "type": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"definition\": [\n    {\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"counterparty_alias\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"created\": \"\",\n      \"description\": \"\",\n      \"fraction\": 0,\n      \"id\": 0,\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"payment_id\": 0,\n  \"type\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"definition\": [\n    {\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"counterparty_alias\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"created\": \"\",\n      \"description\": \"\",\n      \"fraction\": 0,\n      \"id\": 0,\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"payment_id\": 0,\n  \"type\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"definition\": [\n    {\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"counterparty_alias\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"created\": \"\",\n      \"description\": \"\",\n      \"fraction\": 0,\n      \"id\": 0,\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"payment_id\": 0,\n  \"type\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"definition\": [\n    {\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"counterparty_alias\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"created\": \"\",\n      \"description\": \"\",\n      \"fraction\": 0,\n      \"id\": 0,\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"payment_id\": 0,\n  \"type\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  definition: [
    {
      amount: {
        currency: '',
        value: ''
      },
      counterparty_alias: {
        name: '',
        service: '',
        type: '',
        value: ''
      },
      created: '',
      description: '',
      fraction: 0,
      id: 0,
      type: '',
      updated: ''
    }
  ],
  payment_id: 0,
  type: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    definition: [
      {
        amount: {currency: '', value: ''},
        counterparty_alias: {name: '', service: '', type: '', value: ''},
        created: '',
        description: '',
        fraction: 0,
        id: 0,
        type: '',
        updated: ''
      }
    ],
    payment_id: 0,
    type: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"definition":[{"amount":{"currency":"","value":""},"counterparty_alias":{"name":"","service":"","type":"","value":""},"created":"","description":"","fraction":0,"id":0,"type":"","updated":""}],"payment_id":0,"type":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "definition": [\n    {\n      "amount": {\n        "currency": "",\n        "value": ""\n      },\n      "counterparty_alias": {\n        "name": "",\n        "service": "",\n        "type": "",\n        "value": ""\n      },\n      "created": "",\n      "description": "",\n      "fraction": 0,\n      "id": 0,\n      "type": "",\n      "updated": ""\n    }\n  ],\n  "payment_id": 0,\n  "type": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"definition\": [\n    {\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"counterparty_alias\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"created\": \"\",\n      \"description\": \"\",\n      \"fraction\": 0,\n      \"id\": 0,\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"payment_id\": 0,\n  \"type\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  definition: [
    {
      amount: {currency: '', value: ''},
      counterparty_alias: {name: '', service: '', type: '', value: ''},
      created: '',
      description: '',
      fraction: 0,
      id: 0,
      type: '',
      updated: ''
    }
  ],
  payment_id: 0,
  type: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    definition: [
      {
        amount: {currency: '', value: ''},
        counterparty_alias: {name: '', service: '', type: '', value: ''},
        created: '',
        description: '',
        fraction: 0,
        id: 0,
        type: '',
        updated: ''
      }
    ],
    payment_id: 0,
    type: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  definition: [
    {
      amount: {
        currency: '',
        value: ''
      },
      counterparty_alias: {
        name: '',
        service: '',
        type: '',
        value: ''
      },
      created: '',
      description: '',
      fraction: 0,
      id: 0,
      type: '',
      updated: ''
    }
  ],
  payment_id: 0,
  type: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    definition: [
      {
        amount: {currency: '', value: ''},
        counterparty_alias: {name: '', service: '', type: '', value: ''},
        created: '',
        description: '',
        fraction: 0,
        id: 0,
        type: '',
        updated: ''
      }
    ],
    payment_id: 0,
    type: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"definition":[{"amount":{"currency":"","value":""},"counterparty_alias":{"name":"","service":"","type":"","value":""},"created":"","description":"","fraction":0,"id":0,"type":"","updated":""}],"payment_id":0,"type":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"definition": @[ @{ @"amount": @{ @"currency": @"", @"value": @"" }, @"counterparty_alias": @{ @"name": @"", @"service": @"", @"type": @"", @"value": @"" }, @"created": @"", @"description": @"", @"fraction": @0, @"id": @0, @"type": @"", @"updated": @"" } ],
                              @"payment_id": @0,
                              @"type": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"definition\": [\n    {\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"counterparty_alias\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"created\": \"\",\n      \"description\": \"\",\n      \"fraction\": 0,\n      \"id\": 0,\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"payment_id\": 0,\n  \"type\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'definition' => [
        [
                'amount' => [
                                'currency' => '',
                                'value' => ''
                ],
                'counterparty_alias' => [
                                'name' => '',
                                'service' => '',
                                'type' => '',
                                'value' => ''
                ],
                'created' => '',
                'description' => '',
                'fraction' => 0,
                'id' => 0,
                'type' => '',
                'updated' => ''
        ]
    ],
    'payment_id' => 0,
    'type' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate', [
  'body' => '{
  "definition": [
    {
      "amount": {
        "currency": "",
        "value": ""
      },
      "counterparty_alias": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "created": "",
      "description": "",
      "fraction": 0,
      "id": 0,
      "type": "",
      "updated": ""
    }
  ],
  "payment_id": 0,
  "type": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'definition' => [
    [
        'amount' => [
                'currency' => '',
                'value' => ''
        ],
        'counterparty_alias' => [
                'name' => '',
                'service' => '',
                'type' => '',
                'value' => ''
        ],
        'created' => '',
        'description' => '',
        'fraction' => 0,
        'id' => 0,
        'type' => '',
        'updated' => ''
    ]
  ],
  'payment_id' => 0,
  'type' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'definition' => [
    [
        'amount' => [
                'currency' => '',
                'value' => ''
        ],
        'counterparty_alias' => [
                'name' => '',
                'service' => '',
                'type' => '',
                'value' => ''
        ],
        'created' => '',
        'description' => '',
        'fraction' => 0,
        'id' => 0,
        'type' => '',
        'updated' => ''
    ]
  ],
  'payment_id' => 0,
  'type' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "definition": [
    {
      "amount": {
        "currency": "",
        "value": ""
      },
      "counterparty_alias": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "created": "",
      "description": "",
      "fraction": 0,
      "id": 0,
      "type": "",
      "updated": ""
    }
  ],
  "payment_id": 0,
  "type": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "definition": [
    {
      "amount": {
        "currency": "",
        "value": ""
      },
      "counterparty_alias": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "created": "",
      "description": "",
      "fraction": 0,
      "id": 0,
      "type": "",
      "updated": ""
    }
  ],
  "payment_id": 0,
  "type": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"definition\": [\n    {\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"counterparty_alias\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"created\": \"\",\n      \"description\": \"\",\n      \"fraction\": 0,\n      \"id\": 0,\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"payment_id\": 0,\n  \"type\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate"

payload = {
    "definition": [
        {
            "amount": {
                "currency": "",
                "value": ""
            },
            "counterparty_alias": {
                "name": "",
                "service": "",
                "type": "",
                "value": ""
            },
            "created": "",
            "description": "",
            "fraction": 0,
            "id": 0,
            "type": "",
            "updated": ""
        }
    ],
    "payment_id": 0,
    "type": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate"

payload <- "{\n  \"definition\": [\n    {\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"counterparty_alias\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"created\": \"\",\n      \"description\": \"\",\n      \"fraction\": 0,\n      \"id\": 0,\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"payment_id\": 0,\n  \"type\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"definition\": [\n    {\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"counterparty_alias\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"created\": \"\",\n      \"description\": \"\",\n      \"fraction\": 0,\n      \"id\": 0,\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"payment_id\": 0,\n  \"type\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"definition\": [\n    {\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"counterparty_alias\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"created\": \"\",\n      \"description\": \"\",\n      \"fraction\": 0,\n      \"id\": 0,\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"payment_id\": 0,\n  \"type\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate";

    let payload = json!({
        "definition": (
            json!({
                "amount": json!({
                    "currency": "",
                    "value": ""
                }),
                "counterparty_alias": json!({
                    "name": "",
                    "service": "",
                    "type": "",
                    "value": ""
                }),
                "created": "",
                "description": "",
                "fraction": 0,
                "id": 0,
                "type": "",
                "updated": ""
            })
        ),
        "payment_id": 0,
        "type": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "definition": [
    {
      "amount": {
        "currency": "",
        "value": ""
      },
      "counterparty_alias": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "created": "",
      "description": "",
      "fraction": 0,
      "id": 0,
      "type": "",
      "updated": ""
    }
  ],
  "payment_id": 0,
  "type": ""
}'
echo '{
  "definition": [
    {
      "amount": {
        "currency": "",
        "value": ""
      },
      "counterparty_alias": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "created": "",
      "description": "",
      "fraction": 0,
      "id": 0,
      "type": "",
      "updated": ""
    }
  ],
  "payment_id": 0,
  "type": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "definition": [\n    {\n      "amount": {\n        "currency": "",\n        "value": ""\n      },\n      "counterparty_alias": {\n        "name": "",\n        "service": "",\n        "type": "",\n        "value": ""\n      },\n      "created": "",\n      "description": "",\n      "fraction": 0,\n      "id": 0,\n      "type": "",\n      "updated": ""\n    }\n  ],\n  "payment_id": 0,\n  "type": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "definition": [
    [
      "amount": [
        "currency": "",
        "value": ""
      ],
      "counterparty_alias": [
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      ],
      "created": "",
      "description": "",
      "fraction": 0,
      "id": 0,
      "type": "",
      "updated": ""
    ]
  ],
  "payment_id": 0,
  "type": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_PaymentAutoAllocate_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId" {:headers {:user-agent ""
                                                                                                                                        :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId"]
                                                       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}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_PaymentAutoAllocate_for_User
{{baseUrl}}/user/:userID/payment-auto-allocate
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/payment-auto-allocate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/payment-auto-allocate" {:headers {:user-agent ""
                                                                                        :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/payment-auto-allocate"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/payment-auto-allocate"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/payment-auto-allocate");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/payment-auto-allocate"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/payment-auto-allocate HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/payment-auto-allocate")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/payment-auto-allocate"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/payment-auto-allocate")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/payment-auto-allocate")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/payment-auto-allocate');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/payment-auto-allocate',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/payment-auto-allocate';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/payment-auto-allocate',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/payment-auto-allocate")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/payment-auto-allocate',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/payment-auto-allocate',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/payment-auto-allocate');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/payment-auto-allocate',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/payment-auto-allocate';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/payment-auto-allocate"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/payment-auto-allocate" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/payment-auto-allocate",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/payment-auto-allocate', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/payment-auto-allocate');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/payment-auto-allocate');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/payment-auto-allocate' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/payment-auto-allocate' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/payment-auto-allocate", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/payment-auto-allocate"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/payment-auto-allocate"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/payment-auto-allocate")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/payment-auto-allocate') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/payment-auto-allocate";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/payment-auto-allocate \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/payment-auto-allocate \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/payment-auto-allocate
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/payment-auto-allocate")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_PaymentAutoAllocate_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate" {:headers {:user-agent ""
                                                                                                                             :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_PaymentAutoAllocate_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId" {:headers {:user-agent ""
                                                                                                                                     :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_PaymentAutoAllocate_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
itemId
BODY json

{
  "definition": [
    {
      "amount": {
        "currency": "",
        "value": ""
      },
      "counterparty_alias": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "created": "",
      "description": "",
      "fraction": 0,
      "id": 0,
      "type": "",
      "updated": ""
    }
  ],
  "payment_id": 0,
  "type": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"definition\": [\n    {\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"counterparty_alias\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"created\": \"\",\n      \"description\": \"\",\n      \"fraction\": 0,\n      \"id\": 0,\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"payment_id\": 0,\n  \"type\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId" {:headers {:user-agent ""
                                                                                                                                     :x-bunq-client-authentication ""}
                                                                                                                           :content-type :json
                                                                                                                           :form-params {:definition [{:amount {:currency ""
                                                                                                                                                                :value ""}
                                                                                                                                                       :counterparty_alias {:name ""
                                                                                                                                                                            :service ""
                                                                                                                                                                            :type ""
                                                                                                                                                                            :value ""}
                                                                                                                                                       :created ""
                                                                                                                                                       :description ""
                                                                                                                                                       :fraction 0
                                                                                                                                                       :id 0
                                                                                                                                                       :type ""
                                                                                                                                                       :updated ""}]
                                                                                                                                         :payment_id 0
                                                                                                                                         :type ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"definition\": [\n    {\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"counterparty_alias\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"created\": \"\",\n      \"description\": \"\",\n      \"fraction\": 0,\n      \"id\": 0,\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"payment_id\": 0,\n  \"type\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"definition\": [\n    {\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"counterparty_alias\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"created\": \"\",\n      \"description\": \"\",\n      \"fraction\": 0,\n      \"id\": 0,\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"payment_id\": 0,\n  \"type\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"definition\": [\n    {\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"counterparty_alias\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"created\": \"\",\n      \"description\": \"\",\n      \"fraction\": 0,\n      \"id\": 0,\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"payment_id\": 0,\n  \"type\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId"

	payload := strings.NewReader("{\n  \"definition\": [\n    {\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"counterparty_alias\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"created\": \"\",\n      \"description\": \"\",\n      \"fraction\": 0,\n      \"id\": 0,\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"payment_id\": 0,\n  \"type\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 383

{
  "definition": [
    {
      "amount": {
        "currency": "",
        "value": ""
      },
      "counterparty_alias": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "created": "",
      "description": "",
      "fraction": 0,
      "id": 0,
      "type": "",
      "updated": ""
    }
  ],
  "payment_id": 0,
  "type": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"definition\": [\n    {\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"counterparty_alias\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"created\": \"\",\n      \"description\": \"\",\n      \"fraction\": 0,\n      \"id\": 0,\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"payment_id\": 0,\n  \"type\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"definition\": [\n    {\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"counterparty_alias\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"created\": \"\",\n      \"description\": \"\",\n      \"fraction\": 0,\n      \"id\": 0,\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"payment_id\": 0,\n  \"type\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"definition\": [\n    {\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"counterparty_alias\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"created\": \"\",\n      \"description\": \"\",\n      \"fraction\": 0,\n      \"id\": 0,\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"payment_id\": 0,\n  \"type\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"definition\": [\n    {\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"counterparty_alias\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"created\": \"\",\n      \"description\": \"\",\n      \"fraction\": 0,\n      \"id\": 0,\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"payment_id\": 0,\n  \"type\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  definition: [
    {
      amount: {
        currency: '',
        value: ''
      },
      counterparty_alias: {
        name: '',
        service: '',
        type: '',
        value: ''
      },
      created: '',
      description: '',
      fraction: 0,
      id: 0,
      type: '',
      updated: ''
    }
  ],
  payment_id: 0,
  type: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    definition: [
      {
        amount: {currency: '', value: ''},
        counterparty_alias: {name: '', service: '', type: '', value: ''},
        created: '',
        description: '',
        fraction: 0,
        id: 0,
        type: '',
        updated: ''
      }
    ],
    payment_id: 0,
    type: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"definition":[{"amount":{"currency":"","value":""},"counterparty_alias":{"name":"","service":"","type":"","value":""},"created":"","description":"","fraction":0,"id":0,"type":"","updated":""}],"payment_id":0,"type":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "definition": [\n    {\n      "amount": {\n        "currency": "",\n        "value": ""\n      },\n      "counterparty_alias": {\n        "name": "",\n        "service": "",\n        "type": "",\n        "value": ""\n      },\n      "created": "",\n      "description": "",\n      "fraction": 0,\n      "id": 0,\n      "type": "",\n      "updated": ""\n    }\n  ],\n  "payment_id": 0,\n  "type": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"definition\": [\n    {\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"counterparty_alias\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"created\": \"\",\n      \"description\": \"\",\n      \"fraction\": 0,\n      \"id\": 0,\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"payment_id\": 0,\n  \"type\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  definition: [
    {
      amount: {currency: '', value: ''},
      counterparty_alias: {name: '', service: '', type: '', value: ''},
      created: '',
      description: '',
      fraction: 0,
      id: 0,
      type: '',
      updated: ''
    }
  ],
  payment_id: 0,
  type: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    definition: [
      {
        amount: {currency: '', value: ''},
        counterparty_alias: {name: '', service: '', type: '', value: ''},
        created: '',
        description: '',
        fraction: 0,
        id: 0,
        type: '',
        updated: ''
      }
    ],
    payment_id: 0,
    type: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  definition: [
    {
      amount: {
        currency: '',
        value: ''
      },
      counterparty_alias: {
        name: '',
        service: '',
        type: '',
        value: ''
      },
      created: '',
      description: '',
      fraction: 0,
      id: 0,
      type: '',
      updated: ''
    }
  ],
  payment_id: 0,
  type: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    definition: [
      {
        amount: {currency: '', value: ''},
        counterparty_alias: {name: '', service: '', type: '', value: ''},
        created: '',
        description: '',
        fraction: 0,
        id: 0,
        type: '',
        updated: ''
      }
    ],
    payment_id: 0,
    type: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"definition":[{"amount":{"currency":"","value":""},"counterparty_alias":{"name":"","service":"","type":"","value":""},"created":"","description":"","fraction":0,"id":0,"type":"","updated":""}],"payment_id":0,"type":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"definition": @[ @{ @"amount": @{ @"currency": @"", @"value": @"" }, @"counterparty_alias": @{ @"name": @"", @"service": @"", @"type": @"", @"value": @"" }, @"created": @"", @"description": @"", @"fraction": @0, @"id": @0, @"type": @"", @"updated": @"" } ],
                              @"payment_id": @0,
                              @"type": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"definition\": [\n    {\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"counterparty_alias\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"created\": \"\",\n      \"description\": \"\",\n      \"fraction\": 0,\n      \"id\": 0,\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"payment_id\": 0,\n  \"type\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'definition' => [
        [
                'amount' => [
                                'currency' => '',
                                'value' => ''
                ],
                'counterparty_alias' => [
                                'name' => '',
                                'service' => '',
                                'type' => '',
                                'value' => ''
                ],
                'created' => '',
                'description' => '',
                'fraction' => 0,
                'id' => 0,
                'type' => '',
                'updated' => ''
        ]
    ],
    'payment_id' => 0,
    'type' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId', [
  'body' => '{
  "definition": [
    {
      "amount": {
        "currency": "",
        "value": ""
      },
      "counterparty_alias": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "created": "",
      "description": "",
      "fraction": 0,
      "id": 0,
      "type": "",
      "updated": ""
    }
  ],
  "payment_id": 0,
  "type": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'definition' => [
    [
        'amount' => [
                'currency' => '',
                'value' => ''
        ],
        'counterparty_alias' => [
                'name' => '',
                'service' => '',
                'type' => '',
                'value' => ''
        ],
        'created' => '',
        'description' => '',
        'fraction' => 0,
        'id' => 0,
        'type' => '',
        'updated' => ''
    ]
  ],
  'payment_id' => 0,
  'type' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'definition' => [
    [
        'amount' => [
                'currency' => '',
                'value' => ''
        ],
        'counterparty_alias' => [
                'name' => '',
                'service' => '',
                'type' => '',
                'value' => ''
        ],
        'created' => '',
        'description' => '',
        'fraction' => 0,
        'id' => 0,
        'type' => '',
        'updated' => ''
    ]
  ],
  'payment_id' => 0,
  'type' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "definition": [
    {
      "amount": {
        "currency": "",
        "value": ""
      },
      "counterparty_alias": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "created": "",
      "description": "",
      "fraction": 0,
      "id": 0,
      "type": "",
      "updated": ""
    }
  ],
  "payment_id": 0,
  "type": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "definition": [
    {
      "amount": {
        "currency": "",
        "value": ""
      },
      "counterparty_alias": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "created": "",
      "description": "",
      "fraction": 0,
      "id": 0,
      "type": "",
      "updated": ""
    }
  ],
  "payment_id": 0,
  "type": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"definition\": [\n    {\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"counterparty_alias\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"created\": \"\",\n      \"description\": \"\",\n      \"fraction\": 0,\n      \"id\": 0,\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"payment_id\": 0,\n  \"type\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId"

payload = {
    "definition": [
        {
            "amount": {
                "currency": "",
                "value": ""
            },
            "counterparty_alias": {
                "name": "",
                "service": "",
                "type": "",
                "value": ""
            },
            "created": "",
            "description": "",
            "fraction": 0,
            "id": 0,
            "type": "",
            "updated": ""
        }
    ],
    "payment_id": 0,
    "type": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId"

payload <- "{\n  \"definition\": [\n    {\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"counterparty_alias\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"created\": \"\",\n      \"description\": \"\",\n      \"fraction\": 0,\n      \"id\": 0,\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"payment_id\": 0,\n  \"type\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"definition\": [\n    {\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"counterparty_alias\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"created\": \"\",\n      \"description\": \"\",\n      \"fraction\": 0,\n      \"id\": 0,\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"payment_id\": 0,\n  \"type\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"definition\": [\n    {\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"counterparty_alias\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"created\": \"\",\n      \"description\": \"\",\n      \"fraction\": 0,\n      \"id\": 0,\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"payment_id\": 0,\n  \"type\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId";

    let payload = json!({
        "definition": (
            json!({
                "amount": json!({
                    "currency": "",
                    "value": ""
                }),
                "counterparty_alias": json!({
                    "name": "",
                    "service": "",
                    "type": "",
                    "value": ""
                }),
                "created": "",
                "description": "",
                "fraction": 0,
                "id": 0,
                "type": "",
                "updated": ""
            })
        ),
        "payment_id": 0,
        "type": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "definition": [
    {
      "amount": {
        "currency": "",
        "value": ""
      },
      "counterparty_alias": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "created": "",
      "description": "",
      "fraction": 0,
      "id": 0,
      "type": "",
      "updated": ""
    }
  ],
  "payment_id": 0,
  "type": ""
}'
echo '{
  "definition": [
    {
      "amount": {
        "currency": "",
        "value": ""
      },
      "counterparty_alias": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "created": "",
      "description": "",
      "fraction": 0,
      "id": 0,
      "type": "",
      "updated": ""
    }
  ],
  "payment_id": 0,
  "type": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "definition": [\n    {\n      "amount": {\n        "currency": "",\n        "value": ""\n      },\n      "counterparty_alias": {\n        "name": "",\n        "service": "",\n        "type": "",\n        "value": ""\n      },\n      "created": "",\n      "description": "",\n      "fraction": 0,\n      "id": 0,\n      "type": "",\n      "updated": ""\n    }\n  ],\n  "payment_id": 0,\n  "type": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "definition": [
    [
      "amount": [
        "currency": "",
        "value": ""
      ],
      "counterparty_alias": [
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      ],
      "created": "",
      "description": "",
      "fraction": 0,
      "id": 0,
      "type": "",
      "updated": ""
    ]
  ],
  "payment_id": 0,
  "type": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-auto-allocate/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_PaymentBatch_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
BODY json

{
  "payments": {
    "Payment": []
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"payments\": {\n    \"Payment\": []\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch" {:headers {:user-agent ""
                                                                                                                      :x-bunq-client-authentication ""}
                                                                                                            :content-type :json
                                                                                                            :form-params {:payments {:Payment []}}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"payments\": {\n    \"Payment\": []\n  }\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"payments\": {\n    \"Payment\": []\n  }\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"payments\": {\n    \"Payment\": []\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch"

	payload := strings.NewReader("{\n  \"payments\": {\n    \"Payment\": []\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 41

{
  "payments": {
    "Payment": []
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"payments\": {\n    \"Payment\": []\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"payments\": {\n    \"Payment\": []\n  }\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"payments\": {\n    \"Payment\": []\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"payments\": {\n    \"Payment\": []\n  }\n}")
  .asString();
const data = JSON.stringify({
  payments: {
    Payment: []
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {payments: {Payment: []}}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"payments":{"Payment":[]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "payments": {\n    "Payment": []\n  }\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"payments\": {\n    \"Payment\": []\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({payments: {Payment: []}}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {payments: {Payment: []}},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  payments: {
    Payment: []
  }
});

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}}/user/:userID/monetary-account/:monetary-accountID/payment-batch',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {payments: {Payment: []}}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"payments":{"Payment":[]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"payments": @{ @"Payment": @[  ] } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"payments\": {\n    \"Payment\": []\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'payments' => [
        'Payment' => [
                
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch', [
  'body' => '{
  "payments": {
    "Payment": []
  }
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'payments' => [
    'Payment' => [
        
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'payments' => [
    'Payment' => [
        
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "payments": {
    "Payment": []
  }
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "payments": {
    "Payment": []
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"payments\": {\n    \"Payment\": []\n  }\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch"

payload = { "payments": { "Payment": [] } }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch"

payload <- "{\n  \"payments\": {\n    \"Payment\": []\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"payments\": {\n    \"Payment\": []\n  }\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"payments\": {\n    \"Payment\": []\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch";

    let payload = json!({"payments": json!({"Payment": ()})});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "payments": {
    "Payment": []
  }
}'
echo '{
  "payments": {
    "Payment": []
  }
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "payments": {\n    "Payment": []\n  }\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["payments": ["Payment": []]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_PaymentBatch_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch" {:headers {:user-agent ""
                                                                                                                     :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_PaymentBatch_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId" {:headers {:user-agent ""
                                                                                                                             :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_PaymentBatch_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
itemId
BODY json

{
  "payments": {
    "Payment": []
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"payments\": {\n    \"Payment\": []\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId" {:headers {:user-agent ""
                                                                                                                             :x-bunq-client-authentication ""}
                                                                                                                   :content-type :json
                                                                                                                   :form-params {:payments {:Payment []}}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"payments\": {\n    \"Payment\": []\n  }\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"payments\": {\n    \"Payment\": []\n  }\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"payments\": {\n    \"Payment\": []\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId"

	payload := strings.NewReader("{\n  \"payments\": {\n    \"Payment\": []\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 41

{
  "payments": {
    "Payment": []
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"payments\": {\n    \"Payment\": []\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"payments\": {\n    \"Payment\": []\n  }\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"payments\": {\n    \"Payment\": []\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"payments\": {\n    \"Payment\": []\n  }\n}")
  .asString();
const data = JSON.stringify({
  payments: {
    Payment: []
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {payments: {Payment: []}}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"payments":{"Payment":[]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "payments": {\n    "Payment": []\n  }\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"payments\": {\n    \"Payment\": []\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({payments: {Payment: []}}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {payments: {Payment: []}},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  payments: {
    Payment: []
  }
});

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}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {payments: {Payment: []}}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"payments":{"Payment":[]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"payments": @{ @"Payment": @[  ] } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"payments\": {\n    \"Payment\": []\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'payments' => [
        'Payment' => [
                
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId', [
  'body' => '{
  "payments": {
    "Payment": []
  }
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'payments' => [
    'Payment' => [
        
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'payments' => [
    'Payment' => [
        
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "payments": {
    "Payment": []
  }
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "payments": {
    "Payment": []
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"payments\": {\n    \"Payment\": []\n  }\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId"

payload = { "payments": { "Payment": [] } }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId"

payload <- "{\n  \"payments\": {\n    \"Payment\": []\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"payments\": {\n    \"Payment\": []\n  }\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"payments\": {\n    \"Payment\": []\n  }\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId";

    let payload = json!({"payments": json!({"Payment": ()})});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "payments": {
    "Payment": []
  }
}'
echo '{
  "payments": {
    "Payment": []
  }
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "payments": {\n    "Payment": []\n  }\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["payments": ["Payment": []]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/payment-batch/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_PaymentServiceProviderCredential
{{baseUrl}}/payment-service-provider-credential
HEADERS

User-Agent
X-Bunq-Client-Authentication
BODY json

{
  "client_payment_service_provider_certificate": "",
  "client_payment_service_provider_certificate_chain": "",
  "client_public_key_signature": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/payment-service-provider-credential");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"client_payment_service_provider_certificate\": \"\",\n  \"client_payment_service_provider_certificate_chain\": \"\",\n  \"client_public_key_signature\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/payment-service-provider-credential" {:headers {:user-agent ""
                                                                                          :x-bunq-client-authentication ""}
                                                                                :content-type :json
                                                                                :form-params {:client_payment_service_provider_certificate ""
                                                                                              :client_payment_service_provider_certificate_chain ""
                                                                                              :client_public_key_signature ""}})
require "http/client"

url = "{{baseUrl}}/payment-service-provider-credential"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"client_payment_service_provider_certificate\": \"\",\n  \"client_payment_service_provider_certificate_chain\": \"\",\n  \"client_public_key_signature\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/payment-service-provider-credential"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"client_payment_service_provider_certificate\": \"\",\n  \"client_payment_service_provider_certificate_chain\": \"\",\n  \"client_public_key_signature\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/payment-service-provider-credential");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"client_payment_service_provider_certificate\": \"\",\n  \"client_payment_service_provider_certificate_chain\": \"\",\n  \"client_public_key_signature\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/payment-service-provider-credential"

	payload := strings.NewReader("{\n  \"client_payment_service_provider_certificate\": \"\",\n  \"client_payment_service_provider_certificate_chain\": \"\",\n  \"client_public_key_signature\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/payment-service-provider-credential HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 151

{
  "client_payment_service_provider_certificate": "",
  "client_payment_service_provider_certificate_chain": "",
  "client_public_key_signature": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/payment-service-provider-credential")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"client_payment_service_provider_certificate\": \"\",\n  \"client_payment_service_provider_certificate_chain\": \"\",\n  \"client_public_key_signature\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/payment-service-provider-credential"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"client_payment_service_provider_certificate\": \"\",\n  \"client_payment_service_provider_certificate_chain\": \"\",\n  \"client_public_key_signature\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"client_payment_service_provider_certificate\": \"\",\n  \"client_payment_service_provider_certificate_chain\": \"\",\n  \"client_public_key_signature\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/payment-service-provider-credential")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/payment-service-provider-credential")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"client_payment_service_provider_certificate\": \"\",\n  \"client_payment_service_provider_certificate_chain\": \"\",\n  \"client_public_key_signature\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  client_payment_service_provider_certificate: '',
  client_payment_service_provider_certificate_chain: '',
  client_public_key_signature: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/payment-service-provider-credential');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/payment-service-provider-credential',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    client_payment_service_provider_certificate: '',
    client_payment_service_provider_certificate_chain: '',
    client_public_key_signature: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/payment-service-provider-credential';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"client_payment_service_provider_certificate":"","client_payment_service_provider_certificate_chain":"","client_public_key_signature":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/payment-service-provider-credential',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "client_payment_service_provider_certificate": "",\n  "client_payment_service_provider_certificate_chain": "",\n  "client_public_key_signature": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"client_payment_service_provider_certificate\": \"\",\n  \"client_payment_service_provider_certificate_chain\": \"\",\n  \"client_public_key_signature\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/payment-service-provider-credential")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/payment-service-provider-credential',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  client_payment_service_provider_certificate: '',
  client_payment_service_provider_certificate_chain: '',
  client_public_key_signature: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/payment-service-provider-credential',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    client_payment_service_provider_certificate: '',
    client_payment_service_provider_certificate_chain: '',
    client_public_key_signature: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/payment-service-provider-credential');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  client_payment_service_provider_certificate: '',
  client_payment_service_provider_certificate_chain: '',
  client_public_key_signature: ''
});

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}}/payment-service-provider-credential',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    client_payment_service_provider_certificate: '',
    client_payment_service_provider_certificate_chain: '',
    client_public_key_signature: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/payment-service-provider-credential';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"client_payment_service_provider_certificate":"","client_payment_service_provider_certificate_chain":"","client_public_key_signature":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"client_payment_service_provider_certificate": @"",
                              @"client_payment_service_provider_certificate_chain": @"",
                              @"client_public_key_signature": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/payment-service-provider-credential"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/payment-service-provider-credential" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"client_payment_service_provider_certificate\": \"\",\n  \"client_payment_service_provider_certificate_chain\": \"\",\n  \"client_public_key_signature\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/payment-service-provider-credential",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'client_payment_service_provider_certificate' => '',
    'client_payment_service_provider_certificate_chain' => '',
    'client_public_key_signature' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/payment-service-provider-credential', [
  'body' => '{
  "client_payment_service_provider_certificate": "",
  "client_payment_service_provider_certificate_chain": "",
  "client_public_key_signature": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/payment-service-provider-credential');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'client_payment_service_provider_certificate' => '',
  'client_payment_service_provider_certificate_chain' => '',
  'client_public_key_signature' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'client_payment_service_provider_certificate' => '',
  'client_payment_service_provider_certificate_chain' => '',
  'client_public_key_signature' => ''
]));
$request->setRequestUrl('{{baseUrl}}/payment-service-provider-credential');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/payment-service-provider-credential' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "client_payment_service_provider_certificate": "",
  "client_payment_service_provider_certificate_chain": "",
  "client_public_key_signature": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/payment-service-provider-credential' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "client_payment_service_provider_certificate": "",
  "client_payment_service_provider_certificate_chain": "",
  "client_public_key_signature": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"client_payment_service_provider_certificate\": \"\",\n  \"client_payment_service_provider_certificate_chain\": \"\",\n  \"client_public_key_signature\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/payment-service-provider-credential", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/payment-service-provider-credential"

payload = {
    "client_payment_service_provider_certificate": "",
    "client_payment_service_provider_certificate_chain": "",
    "client_public_key_signature": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/payment-service-provider-credential"

payload <- "{\n  \"client_payment_service_provider_certificate\": \"\",\n  \"client_payment_service_provider_certificate_chain\": \"\",\n  \"client_public_key_signature\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/payment-service-provider-credential")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"client_payment_service_provider_certificate\": \"\",\n  \"client_payment_service_provider_certificate_chain\": \"\",\n  \"client_public_key_signature\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/payment-service-provider-credential') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"client_payment_service_provider_certificate\": \"\",\n  \"client_payment_service_provider_certificate_chain\": \"\",\n  \"client_public_key_signature\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/payment-service-provider-credential";

    let payload = json!({
        "client_payment_service_provider_certificate": "",
        "client_payment_service_provider_certificate_chain": "",
        "client_public_key_signature": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/payment-service-provider-credential \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "client_payment_service_provider_certificate": "",
  "client_payment_service_provider_certificate_chain": "",
  "client_public_key_signature": ""
}'
echo '{
  "client_payment_service_provider_certificate": "",
  "client_payment_service_provider_certificate_chain": "",
  "client_public_key_signature": ""
}' |  \
  http POST {{baseUrl}}/payment-service-provider-credential \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "client_payment_service_provider_certificate": "",\n  "client_payment_service_provider_certificate_chain": "",\n  "client_public_key_signature": ""\n}' \
  --output-document \
  - {{baseUrl}}/payment-service-provider-credential
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "client_payment_service_provider_certificate": "",
  "client_payment_service_provider_certificate_chain": "",
  "client_public_key_signature": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/payment-service-provider-credential")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_PaymentServiceProviderCredential
{{baseUrl}}/payment-service-provider-credential/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/payment-service-provider-credential/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/payment-service-provider-credential/:itemId" {:headers {:user-agent ""
                                                                                                 :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/payment-service-provider-credential/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/payment-service-provider-credential/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/payment-service-provider-credential/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/payment-service-provider-credential/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/payment-service-provider-credential/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/payment-service-provider-credential/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/payment-service-provider-credential/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/payment-service-provider-credential/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/payment-service-provider-credential/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/payment-service-provider-credential/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/payment-service-provider-credential/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/payment-service-provider-credential/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/payment-service-provider-credential/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/payment-service-provider-credential/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/payment-service-provider-credential/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/payment-service-provider-credential/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/payment-service-provider-credential/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/payment-service-provider-credential/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/payment-service-provider-credential/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/payment-service-provider-credential/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/payment-service-provider-credential/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/payment-service-provider-credential/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/payment-service-provider-credential/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/payment-service-provider-credential/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/payment-service-provider-credential/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/payment-service-provider-credential/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/payment-service-provider-credential/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/payment-service-provider-credential/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/payment-service-provider-credential/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/payment-service-provider-credential/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/payment-service-provider-credential/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/payment-service-provider-credential/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/payment-service-provider-credential/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/payment-service-provider-credential/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/payment-service-provider-credential/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/payment-service-provider-credential/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/payment-service-provider-credential/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_PaymentServiceProviderDraftPayment_for_User
{{baseUrl}}/user/:userID/payment-service-provider-draft-payment
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
BODY json

{
  "amount": {
    "currency": "",
    "value": ""
  },
  "counterparty_iban": "",
  "counterparty_name": "",
  "description": "",
  "sender_iban": "",
  "sender_name": "",
  "status": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_iban\": \"\",\n  \"counterparty_name\": \"\",\n  \"description\": \"\",\n  \"sender_iban\": \"\",\n  \"sender_name\": \"\",\n  \"status\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment" {:headers {:user-agent ""
                                                                                                          :x-bunq-client-authentication ""}
                                                                                                :content-type :json
                                                                                                :form-params {:amount {:currency ""
                                                                                                                       :value ""}
                                                                                                              :counterparty_iban ""
                                                                                                              :counterparty_name ""
                                                                                                              :description ""
                                                                                                              :sender_iban ""
                                                                                                              :sender_name ""
                                                                                                              :status ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_iban\": \"\",\n  \"counterparty_name\": \"\",\n  \"description\": \"\",\n  \"sender_iban\": \"\",\n  \"sender_name\": \"\",\n  \"status\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/payment-service-provider-draft-payment"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_iban\": \"\",\n  \"counterparty_name\": \"\",\n  \"description\": \"\",\n  \"sender_iban\": \"\",\n  \"sender_name\": \"\",\n  \"status\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/payment-service-provider-draft-payment");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_iban\": \"\",\n  \"counterparty_name\": \"\",\n  \"description\": \"\",\n  \"sender_iban\": \"\",\n  \"sender_name\": \"\",\n  \"status\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment"

	payload := strings.NewReader("{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_iban\": \"\",\n  \"counterparty_name\": \"\",\n  \"description\": \"\",\n  \"sender_iban\": \"\",\n  \"sender_name\": \"\",\n  \"status\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/payment-service-provider-draft-payment HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 190

{
  "amount": {
    "currency": "",
    "value": ""
  },
  "counterparty_iban": "",
  "counterparty_name": "",
  "description": "",
  "sender_iban": "",
  "sender_name": "",
  "status": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_iban\": \"\",\n  \"counterparty_name\": \"\",\n  \"description\": \"\",\n  \"sender_iban\": \"\",\n  \"sender_name\": \"\",\n  \"status\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/payment-service-provider-draft-payment"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_iban\": \"\",\n  \"counterparty_name\": \"\",\n  \"description\": \"\",\n  \"sender_iban\": \"\",\n  \"sender_name\": \"\",\n  \"status\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_iban\": \"\",\n  \"counterparty_name\": \"\",\n  \"description\": \"\",\n  \"sender_iban\": \"\",\n  \"sender_name\": \"\",\n  \"status\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/payment-service-provider-draft-payment")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/payment-service-provider-draft-payment")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_iban\": \"\",\n  \"counterparty_name\": \"\",\n  \"description\": \"\",\n  \"sender_iban\": \"\",\n  \"sender_name\": \"\",\n  \"status\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  amount: {
    currency: '',
    value: ''
  },
  counterparty_iban: '',
  counterparty_name: '',
  description: '',
  sender_iban: '',
  sender_name: '',
  status: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    amount: {currency: '', value: ''},
    counterparty_iban: '',
    counterparty_name: '',
    description: '',
    sender_iban: '',
    sender_name: '',
    status: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"amount":{"currency":"","value":""},"counterparty_iban":"","counterparty_name":"","description":"","sender_iban":"","sender_name":"","status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "amount": {\n    "currency": "",\n    "value": ""\n  },\n  "counterparty_iban": "",\n  "counterparty_name": "",\n  "description": "",\n  "sender_iban": "",\n  "sender_name": "",\n  "status": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_iban\": \"\",\n  \"counterparty_name\": \"\",\n  \"description\": \"\",\n  \"sender_iban\": \"\",\n  \"sender_name\": \"\",\n  \"status\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/payment-service-provider-draft-payment")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/payment-service-provider-draft-payment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  amount: {currency: '', value: ''},
  counterparty_iban: '',
  counterparty_name: '',
  description: '',
  sender_iban: '',
  sender_name: '',
  status: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    amount: {currency: '', value: ''},
    counterparty_iban: '',
    counterparty_name: '',
    description: '',
    sender_iban: '',
    sender_name: '',
    status: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  amount: {
    currency: '',
    value: ''
  },
  counterparty_iban: '',
  counterparty_name: '',
  description: '',
  sender_iban: '',
  sender_name: '',
  status: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    amount: {currency: '', value: ''},
    counterparty_iban: '',
    counterparty_name: '',
    description: '',
    sender_iban: '',
    sender_name: '',
    status: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"amount":{"currency":"","value":""},"counterparty_iban":"","counterparty_name":"","description":"","sender_iban":"","sender_name":"","status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"amount": @{ @"currency": @"", @"value": @"" },
                              @"counterparty_iban": @"",
                              @"counterparty_name": @"",
                              @"description": @"",
                              @"sender_iban": @"",
                              @"sender_name": @"",
                              @"status": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/payment-service-provider-draft-payment"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_iban\": \"\",\n  \"counterparty_name\": \"\",\n  \"description\": \"\",\n  \"sender_iban\": \"\",\n  \"sender_name\": \"\",\n  \"status\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'amount' => [
        'currency' => '',
        'value' => ''
    ],
    'counterparty_iban' => '',
    'counterparty_name' => '',
    'description' => '',
    'sender_iban' => '',
    'sender_name' => '',
    'status' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment', [
  'body' => '{
  "amount": {
    "currency": "",
    "value": ""
  },
  "counterparty_iban": "",
  "counterparty_name": "",
  "description": "",
  "sender_iban": "",
  "sender_name": "",
  "status": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/payment-service-provider-draft-payment');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'amount' => [
    'currency' => '',
    'value' => ''
  ],
  'counterparty_iban' => '',
  'counterparty_name' => '',
  'description' => '',
  'sender_iban' => '',
  'sender_name' => '',
  'status' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'amount' => [
    'currency' => '',
    'value' => ''
  ],
  'counterparty_iban' => '',
  'counterparty_name' => '',
  'description' => '',
  'sender_iban' => '',
  'sender_name' => '',
  'status' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/payment-service-provider-draft-payment');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "amount": {
    "currency": "",
    "value": ""
  },
  "counterparty_iban": "",
  "counterparty_name": "",
  "description": "",
  "sender_iban": "",
  "sender_name": "",
  "status": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "amount": {
    "currency": "",
    "value": ""
  },
  "counterparty_iban": "",
  "counterparty_name": "",
  "description": "",
  "sender_iban": "",
  "sender_name": "",
  "status": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_iban\": \"\",\n  \"counterparty_name\": \"\",\n  \"description\": \"\",\n  \"sender_iban\": \"\",\n  \"sender_name\": \"\",\n  \"status\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/payment-service-provider-draft-payment", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment"

payload = {
    "amount": {
        "currency": "",
        "value": ""
    },
    "counterparty_iban": "",
    "counterparty_name": "",
    "description": "",
    "sender_iban": "",
    "sender_name": "",
    "status": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment"

payload <- "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_iban\": \"\",\n  \"counterparty_name\": \"\",\n  \"description\": \"\",\n  \"sender_iban\": \"\",\n  \"sender_name\": \"\",\n  \"status\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/payment-service-provider-draft-payment")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_iban\": \"\",\n  \"counterparty_name\": \"\",\n  \"description\": \"\",\n  \"sender_iban\": \"\",\n  \"sender_name\": \"\",\n  \"status\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/payment-service-provider-draft-payment') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_iban\": \"\",\n  \"counterparty_name\": \"\",\n  \"description\": \"\",\n  \"sender_iban\": \"\",\n  \"sender_name\": \"\",\n  \"status\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment";

    let payload = json!({
        "amount": json!({
            "currency": "",
            "value": ""
        }),
        "counterparty_iban": "",
        "counterparty_name": "",
        "description": "",
        "sender_iban": "",
        "sender_name": "",
        "status": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/payment-service-provider-draft-payment \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "amount": {
    "currency": "",
    "value": ""
  },
  "counterparty_iban": "",
  "counterparty_name": "",
  "description": "",
  "sender_iban": "",
  "sender_name": "",
  "status": ""
}'
echo '{
  "amount": {
    "currency": "",
    "value": ""
  },
  "counterparty_iban": "",
  "counterparty_name": "",
  "description": "",
  "sender_iban": "",
  "sender_name": "",
  "status": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/payment-service-provider-draft-payment \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "amount": {\n    "currency": "",\n    "value": ""\n  },\n  "counterparty_iban": "",\n  "counterparty_name": "",\n  "description": "",\n  "sender_iban": "",\n  "sender_name": "",\n  "status": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/payment-service-provider-draft-payment
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "amount": [
    "currency": "",
    "value": ""
  ],
  "counterparty_iban": "",
  "counterparty_name": "",
  "description": "",
  "sender_iban": "",
  "sender_name": "",
  "status": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_PaymentServiceProviderDraftPayment_for_User
{{baseUrl}}/user/:userID/payment-service-provider-draft-payment
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment" {:headers {:user-agent ""
                                                                                                         :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/payment-service-provider-draft-payment"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/payment-service-provider-draft-payment");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/payment-service-provider-draft-payment HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/payment-service-provider-draft-payment"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/payment-service-provider-draft-payment")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/payment-service-provider-draft-payment")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/payment-service-provider-draft-payment")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/payment-service-provider-draft-payment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/payment-service-provider-draft-payment"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/payment-service-provider-draft-payment');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/payment-service-provider-draft-payment');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/payment-service-provider-draft-payment", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/payment-service-provider-draft-payment")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/payment-service-provider-draft-payment') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/payment-service-provider-draft-payment \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/payment-service-provider-draft-payment \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/payment-service-provider-draft-payment
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_PaymentServiceProviderDraftPayment_for_User
{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId" {:headers {:user-agent ""
                                                                                                                 :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/payment-service-provider-draft-payment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/payment-service-provider-draft-payment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/payment-service-provider-draft-payment/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/payment-service-provider-draft-payment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_PaymentServiceProviderDraftPayment_for_User
{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
BODY json

{
  "amount": {
    "currency": "",
    "value": ""
  },
  "counterparty_iban": "",
  "counterparty_name": "",
  "description": "",
  "sender_iban": "",
  "sender_name": "",
  "status": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_iban\": \"\",\n  \"counterparty_name\": \"\",\n  \"description\": \"\",\n  \"sender_iban\": \"\",\n  \"sender_name\": \"\",\n  \"status\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId" {:headers {:user-agent ""
                                                                                                                 :x-bunq-client-authentication ""}
                                                                                                       :content-type :json
                                                                                                       :form-params {:amount {:currency ""
                                                                                                                              :value ""}
                                                                                                                     :counterparty_iban ""
                                                                                                                     :counterparty_name ""
                                                                                                                     :description ""
                                                                                                                     :sender_iban ""
                                                                                                                     :sender_name ""
                                                                                                                     :status ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_iban\": \"\",\n  \"counterparty_name\": \"\",\n  \"description\": \"\",\n  \"sender_iban\": \"\",\n  \"sender_name\": \"\",\n  \"status\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_iban\": \"\",\n  \"counterparty_name\": \"\",\n  \"description\": \"\",\n  \"sender_iban\": \"\",\n  \"sender_name\": \"\",\n  \"status\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_iban\": \"\",\n  \"counterparty_name\": \"\",\n  \"description\": \"\",\n  \"sender_iban\": \"\",\n  \"sender_name\": \"\",\n  \"status\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId"

	payload := strings.NewReader("{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_iban\": \"\",\n  \"counterparty_name\": \"\",\n  \"description\": \"\",\n  \"sender_iban\": \"\",\n  \"sender_name\": \"\",\n  \"status\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/payment-service-provider-draft-payment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 190

{
  "amount": {
    "currency": "",
    "value": ""
  },
  "counterparty_iban": "",
  "counterparty_name": "",
  "description": "",
  "sender_iban": "",
  "sender_name": "",
  "status": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_iban\": \"\",\n  \"counterparty_name\": \"\",\n  \"description\": \"\",\n  \"sender_iban\": \"\",\n  \"sender_name\": \"\",\n  \"status\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_iban\": \"\",\n  \"counterparty_name\": \"\",\n  \"description\": \"\",\n  \"sender_iban\": \"\",\n  \"sender_name\": \"\",\n  \"status\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_iban\": \"\",\n  \"counterparty_name\": \"\",\n  \"description\": \"\",\n  \"sender_iban\": \"\",\n  \"sender_name\": \"\",\n  \"status\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_iban\": \"\",\n  \"counterparty_name\": \"\",\n  \"description\": \"\",\n  \"sender_iban\": \"\",\n  \"sender_name\": \"\",\n  \"status\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  amount: {
    currency: '',
    value: ''
  },
  counterparty_iban: '',
  counterparty_name: '',
  description: '',
  sender_iban: '',
  sender_name: '',
  status: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    amount: {currency: '', value: ''},
    counterparty_iban: '',
    counterparty_name: '',
    description: '',
    sender_iban: '',
    sender_name: '',
    status: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"amount":{"currency":"","value":""},"counterparty_iban":"","counterparty_name":"","description":"","sender_iban":"","sender_name":"","status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "amount": {\n    "currency": "",\n    "value": ""\n  },\n  "counterparty_iban": "",\n  "counterparty_name": "",\n  "description": "",\n  "sender_iban": "",\n  "sender_name": "",\n  "status": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_iban\": \"\",\n  \"counterparty_name\": \"\",\n  \"description\": \"\",\n  \"sender_iban\": \"\",\n  \"sender_name\": \"\",\n  \"status\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/payment-service-provider-draft-payment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  amount: {currency: '', value: ''},
  counterparty_iban: '',
  counterparty_name: '',
  description: '',
  sender_iban: '',
  sender_name: '',
  status: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    amount: {currency: '', value: ''},
    counterparty_iban: '',
    counterparty_name: '',
    description: '',
    sender_iban: '',
    sender_name: '',
    status: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  amount: {
    currency: '',
    value: ''
  },
  counterparty_iban: '',
  counterparty_name: '',
  description: '',
  sender_iban: '',
  sender_name: '',
  status: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    amount: {currency: '', value: ''},
    counterparty_iban: '',
    counterparty_name: '',
    description: '',
    sender_iban: '',
    sender_name: '',
    status: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"amount":{"currency":"","value":""},"counterparty_iban":"","counterparty_name":"","description":"","sender_iban":"","sender_name":"","status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"amount": @{ @"currency": @"", @"value": @"" },
                              @"counterparty_iban": @"",
                              @"counterparty_name": @"",
                              @"description": @"",
                              @"sender_iban": @"",
                              @"sender_name": @"",
                              @"status": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_iban\": \"\",\n  \"counterparty_name\": \"\",\n  \"description\": \"\",\n  \"sender_iban\": \"\",\n  \"sender_name\": \"\",\n  \"status\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'amount' => [
        'currency' => '',
        'value' => ''
    ],
    'counterparty_iban' => '',
    'counterparty_name' => '',
    'description' => '',
    'sender_iban' => '',
    'sender_name' => '',
    'status' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId', [
  'body' => '{
  "amount": {
    "currency": "",
    "value": ""
  },
  "counterparty_iban": "",
  "counterparty_name": "",
  "description": "",
  "sender_iban": "",
  "sender_name": "",
  "status": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'amount' => [
    'currency' => '',
    'value' => ''
  ],
  'counterparty_iban' => '',
  'counterparty_name' => '',
  'description' => '',
  'sender_iban' => '',
  'sender_name' => '',
  'status' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'amount' => [
    'currency' => '',
    'value' => ''
  ],
  'counterparty_iban' => '',
  'counterparty_name' => '',
  'description' => '',
  'sender_iban' => '',
  'sender_name' => '',
  'status' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "amount": {
    "currency": "",
    "value": ""
  },
  "counterparty_iban": "",
  "counterparty_name": "",
  "description": "",
  "sender_iban": "",
  "sender_name": "",
  "status": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "amount": {
    "currency": "",
    "value": ""
  },
  "counterparty_iban": "",
  "counterparty_name": "",
  "description": "",
  "sender_iban": "",
  "sender_name": "",
  "status": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_iban\": \"\",\n  \"counterparty_name\": \"\",\n  \"description\": \"\",\n  \"sender_iban\": \"\",\n  \"sender_name\": \"\",\n  \"status\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/payment-service-provider-draft-payment/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId"

payload = {
    "amount": {
        "currency": "",
        "value": ""
    },
    "counterparty_iban": "",
    "counterparty_name": "",
    "description": "",
    "sender_iban": "",
    "sender_name": "",
    "status": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId"

payload <- "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_iban\": \"\",\n  \"counterparty_name\": \"\",\n  \"description\": \"\",\n  \"sender_iban\": \"\",\n  \"sender_name\": \"\",\n  \"status\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_iban\": \"\",\n  \"counterparty_name\": \"\",\n  \"description\": \"\",\n  \"sender_iban\": \"\",\n  \"sender_name\": \"\",\n  \"status\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/payment-service-provider-draft-payment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"amount\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"counterparty_iban\": \"\",\n  \"counterparty_name\": \"\",\n  \"description\": \"\",\n  \"sender_iban\": \"\",\n  \"sender_name\": \"\",\n  \"status\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId";

    let payload = json!({
        "amount": json!({
            "currency": "",
            "value": ""
        }),
        "counterparty_iban": "",
        "counterparty_name": "",
        "description": "",
        "sender_iban": "",
        "sender_name": "",
        "status": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "amount": {
    "currency": "",
    "value": ""
  },
  "counterparty_iban": "",
  "counterparty_name": "",
  "description": "",
  "sender_iban": "",
  "sender_name": "",
  "status": ""
}'
echo '{
  "amount": {
    "currency": "",
    "value": ""
  },
  "counterparty_iban": "",
  "counterparty_name": "",
  "description": "",
  "sender_iban": "",
  "sender_name": "",
  "status": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "amount": {\n    "currency": "",\n    "value": ""\n  },\n  "counterparty_iban": "",\n  "counterparty_name": "",\n  "description": "",\n  "sender_iban": "",\n  "sender_name": "",\n  "status": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "amount": [
    "currency": "",
    "value": ""
  ],
  "counterparty_iban": "",
  "counterparty_name": "",
  "description": "",
  "sender_iban": "",
  "sender_name": "",
  "status": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/payment-service-provider-draft-payment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_PdfContent_for_User_Invoice
{{baseUrl}}/user/:userID/invoice/:invoiceID/pdf-content
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
invoiceID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/invoice/:invoiceID/pdf-content");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/invoice/:invoiceID/pdf-content" {:headers {:user-agent ""
                                                                                                 :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/invoice/:invoiceID/pdf-content"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/invoice/:invoiceID/pdf-content"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/invoice/:invoiceID/pdf-content");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/invoice/:invoiceID/pdf-content"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/invoice/:invoiceID/pdf-content HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/invoice/:invoiceID/pdf-content")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/invoice/:invoiceID/pdf-content"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/invoice/:invoiceID/pdf-content")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/invoice/:invoiceID/pdf-content")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/invoice/:invoiceID/pdf-content');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/invoice/:invoiceID/pdf-content',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/invoice/:invoiceID/pdf-content';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/invoice/:invoiceID/pdf-content',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/invoice/:invoiceID/pdf-content")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/invoice/:invoiceID/pdf-content',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/invoice/:invoiceID/pdf-content',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/invoice/:invoiceID/pdf-content');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/invoice/:invoiceID/pdf-content',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/invoice/:invoiceID/pdf-content';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/invoice/:invoiceID/pdf-content"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/invoice/:invoiceID/pdf-content" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/invoice/:invoiceID/pdf-content",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/invoice/:invoiceID/pdf-content', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/invoice/:invoiceID/pdf-content');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/invoice/:invoiceID/pdf-content');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/invoice/:invoiceID/pdf-content' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/invoice/:invoiceID/pdf-content' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/invoice/:invoiceID/pdf-content", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/invoice/:invoiceID/pdf-content"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/invoice/:invoiceID/pdf-content"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/invoice/:invoiceID/pdf-content")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/invoice/:invoiceID/pdf-content') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/invoice/:invoiceID/pdf-content";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/invoice/:invoiceID/pdf-content \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/invoice/:invoiceID/pdf-content \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/invoice/:invoiceID/pdf-content
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/invoice/:invoiceID/pdf-content")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_RegistrySettlement_for_User_Registry
{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
registryID
BODY json

{}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement" {:headers {:user-agent ""
                                                                                                            :x-bunq-client-authentication ""}
                                                                                                  :content-type :json})
require "http/client"

url = "{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement"

	payload := strings.NewReader("{}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/registry/:registryID/registry-settlement HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 2

{}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{}")
  .asString();
const data = JSON.stringify({});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/registry/:registryID/registry-settlement',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{  };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement', [
  'body' => '{}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement' -Method POST -Headers $headers -ContentType 'application/json' -Body '{}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement' -Method POST -Headers $headers -ContentType 'application/json' -Body '{}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/registry/:registryID/registry-settlement", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement"

payload = {}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement"

payload <- "{}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/registry/:registryID/registry-settlement') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement";

    let payload = json!({});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/registry/:registryID/registry-settlement \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{}'
echo '{}' |  \
  http POST {{baseUrl}}/user/:userID/registry/:registryID/registry-settlement \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{}' \
  --output-document \
  - {{baseUrl}}/user/:userID/registry/:registryID/registry-settlement
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_RegistrySettlement_for_User_Registry
{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
registryID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement" {:headers {:user-agent ""
                                                                                                           :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/registry/:registryID/registry-settlement HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/registry/:registryID/registry-settlement',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/registry/:registryID/registry-settlement", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/registry/:registryID/registry-settlement') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/registry/:registryID/registry-settlement \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/registry/:registryID/registry-settlement \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/registry/:registryID/registry-settlement
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_RegistrySettlement_for_User_Registry
{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
registryID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement/:itemId" {:headers {:user-agent ""
                                                                                                                   :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/registry/:registryID/registry-settlement/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/registry/:registryID/registry-settlement/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/registry/:registryID/registry-settlement/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/registry/:registryID/registry-settlement/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/registry/:registryID/registry-settlement/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/registry/:registryID/registry-settlement/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/registry/:registryID/registry-settlement/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/registry/:registryID/registry-settlement/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_Replace_for_User_Card
{{baseUrl}}/user/:userID/card/:cardID/replace
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
cardID
BODY json

{
  "name_on_card": "",
  "pin_code_assignment": [
    {
      "monetary_account_id": 0,
      "pin_code": "",
      "routing_type": "",
      "type": ""
    }
  ],
  "preferred_name_on_card": "",
  "second_line": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/card/:cardID/replace");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"name_on_card\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"second_line\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/card/:cardID/replace" {:headers {:user-agent ""
                                                                                        :x-bunq-client-authentication ""}
                                                                              :content-type :json
                                                                              :form-params {:name_on_card ""
                                                                                            :pin_code_assignment [{:monetary_account_id 0
                                                                                                                   :pin_code ""
                                                                                                                   :routing_type ""
                                                                                                                   :type ""}]
                                                                                            :preferred_name_on_card ""
                                                                                            :second_line ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/card/:cardID/replace"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"name_on_card\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"second_line\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/card/:cardID/replace"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"name_on_card\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"second_line\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/card/:cardID/replace");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"name_on_card\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"second_line\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/card/:cardID/replace"

	payload := strings.NewReader("{\n  \"name_on_card\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"second_line\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/card/:cardID/replace HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 218

{
  "name_on_card": "",
  "pin_code_assignment": [
    {
      "monetary_account_id": 0,
      "pin_code": "",
      "routing_type": "",
      "type": ""
    }
  ],
  "preferred_name_on_card": "",
  "second_line": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/card/:cardID/replace")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"name_on_card\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"second_line\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/card/:cardID/replace"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"name_on_card\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"second_line\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"name_on_card\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"second_line\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/card/:cardID/replace")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/card/:cardID/replace")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"name_on_card\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"second_line\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  name_on_card: '',
  pin_code_assignment: [
    {
      monetary_account_id: 0,
      pin_code: '',
      routing_type: '',
      type: ''
    }
  ],
  preferred_name_on_card: '',
  second_line: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/card/:cardID/replace');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/card/:cardID/replace',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    name_on_card: '',
    pin_code_assignment: [{monetary_account_id: 0, pin_code: '', routing_type: '', type: ''}],
    preferred_name_on_card: '',
    second_line: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/card/:cardID/replace';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"name_on_card":"","pin_code_assignment":[{"monetary_account_id":0,"pin_code":"","routing_type":"","type":""}],"preferred_name_on_card":"","second_line":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/card/:cardID/replace',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "name_on_card": "",\n  "pin_code_assignment": [\n    {\n      "monetary_account_id": 0,\n      "pin_code": "",\n      "routing_type": "",\n      "type": ""\n    }\n  ],\n  "preferred_name_on_card": "",\n  "second_line": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"name_on_card\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"second_line\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/card/:cardID/replace")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/card/:cardID/replace',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  name_on_card: '',
  pin_code_assignment: [{monetary_account_id: 0, pin_code: '', routing_type: '', type: ''}],
  preferred_name_on_card: '',
  second_line: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/card/:cardID/replace',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    name_on_card: '',
    pin_code_assignment: [{monetary_account_id: 0, pin_code: '', routing_type: '', type: ''}],
    preferred_name_on_card: '',
    second_line: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/card/:cardID/replace');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  name_on_card: '',
  pin_code_assignment: [
    {
      monetary_account_id: 0,
      pin_code: '',
      routing_type: '',
      type: ''
    }
  ],
  preferred_name_on_card: '',
  second_line: ''
});

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}}/user/:userID/card/:cardID/replace',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    name_on_card: '',
    pin_code_assignment: [{monetary_account_id: 0, pin_code: '', routing_type: '', type: ''}],
    preferred_name_on_card: '',
    second_line: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/card/:cardID/replace';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"name_on_card":"","pin_code_assignment":[{"monetary_account_id":0,"pin_code":"","routing_type":"","type":""}],"preferred_name_on_card":"","second_line":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"name_on_card": @"",
                              @"pin_code_assignment": @[ @{ @"monetary_account_id": @0, @"pin_code": @"", @"routing_type": @"", @"type": @"" } ],
                              @"preferred_name_on_card": @"",
                              @"second_line": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/card/:cardID/replace"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/card/:cardID/replace" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"name_on_card\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"second_line\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/card/:cardID/replace",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'name_on_card' => '',
    'pin_code_assignment' => [
        [
                'monetary_account_id' => 0,
                'pin_code' => '',
                'routing_type' => '',
                'type' => ''
        ]
    ],
    'preferred_name_on_card' => '',
    'second_line' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/card/:cardID/replace', [
  'body' => '{
  "name_on_card": "",
  "pin_code_assignment": [
    {
      "monetary_account_id": 0,
      "pin_code": "",
      "routing_type": "",
      "type": ""
    }
  ],
  "preferred_name_on_card": "",
  "second_line": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/card/:cardID/replace');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'name_on_card' => '',
  'pin_code_assignment' => [
    [
        'monetary_account_id' => 0,
        'pin_code' => '',
        'routing_type' => '',
        'type' => ''
    ]
  ],
  'preferred_name_on_card' => '',
  'second_line' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'name_on_card' => '',
  'pin_code_assignment' => [
    [
        'monetary_account_id' => 0,
        'pin_code' => '',
        'routing_type' => '',
        'type' => ''
    ]
  ],
  'preferred_name_on_card' => '',
  'second_line' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/card/:cardID/replace');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/card/:cardID/replace' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "name_on_card": "",
  "pin_code_assignment": [
    {
      "monetary_account_id": 0,
      "pin_code": "",
      "routing_type": "",
      "type": ""
    }
  ],
  "preferred_name_on_card": "",
  "second_line": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/card/:cardID/replace' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "name_on_card": "",
  "pin_code_assignment": [
    {
      "monetary_account_id": 0,
      "pin_code": "",
      "routing_type": "",
      "type": ""
    }
  ],
  "preferred_name_on_card": "",
  "second_line": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"name_on_card\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"second_line\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/card/:cardID/replace", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/card/:cardID/replace"

payload = {
    "name_on_card": "",
    "pin_code_assignment": [
        {
            "monetary_account_id": 0,
            "pin_code": "",
            "routing_type": "",
            "type": ""
        }
    ],
    "preferred_name_on_card": "",
    "second_line": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/card/:cardID/replace"

payload <- "{\n  \"name_on_card\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"second_line\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/card/:cardID/replace")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"name_on_card\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"second_line\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/card/:cardID/replace') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"name_on_card\": \"\",\n  \"pin_code_assignment\": [\n    {\n      \"monetary_account_id\": 0,\n      \"pin_code\": \"\",\n      \"routing_type\": \"\",\n      \"type\": \"\"\n    }\n  ],\n  \"preferred_name_on_card\": \"\",\n  \"second_line\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/card/:cardID/replace";

    let payload = json!({
        "name_on_card": "",
        "pin_code_assignment": (
            json!({
                "monetary_account_id": 0,
                "pin_code": "",
                "routing_type": "",
                "type": ""
            })
        ),
        "preferred_name_on_card": "",
        "second_line": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/card/:cardID/replace \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "name_on_card": "",
  "pin_code_assignment": [
    {
      "monetary_account_id": 0,
      "pin_code": "",
      "routing_type": "",
      "type": ""
    }
  ],
  "preferred_name_on_card": "",
  "second_line": ""
}'
echo '{
  "name_on_card": "",
  "pin_code_assignment": [
    {
      "monetary_account_id": 0,
      "pin_code": "",
      "routing_type": "",
      "type": ""
    }
  ],
  "preferred_name_on_card": "",
  "second_line": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/card/:cardID/replace \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "name_on_card": "",\n  "pin_code_assignment": [\n    {\n      "monetary_account_id": 0,\n      "pin_code": "",\n      "routing_type": "",\n      "type": ""\n    }\n  ],\n  "preferred_name_on_card": "",\n  "second_line": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/card/:cardID/replace
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "name_on_card": "",
  "pin_code_assignment": [
    [
      "monetary_account_id": 0,
      "pin_code": "",
      "routing_type": "",
      "type": ""
    ]
  ],
  "preferred_name_on_card": "",
  "second_line": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/card/:cardID/replace")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_RequestInquiry_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
BODY json

{
  "address_billing": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_shipping": {},
  "allow_amount_higher": false,
  "allow_amount_lower": false,
  "allow_bunqme": false,
  "amount_inquired": {
    "currency": "",
    "value": ""
  },
  "amount_responded": {},
  "attachment": [
    {
      "id": 0
    }
  ],
  "batch_id": 0,
  "bunqme_share_url": "",
  "counterparty_alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "created": "",
  "description": "",
  "event_id": 0,
  "geolocation": {
    "altitude": 0,
    "latitude": 0,
    "longitude": 0,
    "radius": 0
  },
  "id": 0,
  "merchant_reference": "",
  "minimum_age": 0,
  "monetary_account_id": 0,
  "redirect_url": "",
  "reference_split_the_bill": {
    "BillingInvoice": {
      "address": {},
      "alias": {},
      "category": "",
      "chamber_of_commerce_number": "",
      "counterparty_address": {},
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "external_url": "",
      "group": [
        {
          "instance_description": "",
          "item": [
            {
              "billing_date": "",
              "id": 0,
              "quantity": 0,
              "total_vat_exclusive": {},
              "total_vat_inclusive": {},
              "type_description": "",
              "type_description_translated": "",
              "unit_vat_exclusive": {},
              "unit_vat_inclusive": {},
              "vat": 0
            }
          ],
          "product_vat_exclusive": {},
          "product_vat_inclusive": {},
          "type": "",
          "type_description": "",
          "type_description_translated": ""
        }
      ],
      "id": 0,
      "invoice_date": "",
      "invoice_number": "",
      "request_reference_split_the_bill": [
        {
          "id": 0,
          "type": ""
        }
      ],
      "status": "",
      "total_vat": {},
      "total_vat_exclusive": {},
      "total_vat_inclusive": {},
      "updated": "",
      "vat_number": ""
    },
    "DraftPayment": {
      "entries": [
        {
          "alias": {},
          "amount": {},
          "attachment": [
            {
              "id": 0,
              "monetary_account_id": 0
            }
          ],
          "counterparty_alias": {},
          "description": "",
          "id": 0,
          "merchant_reference": "",
          "type": ""
        }
      ],
      "number_of_required_accepts": 0,
      "previous_updated_timestamp": "",
      "schedule": {
        "object": {
          "Payment": {
            "address_billing": {},
            "address_shipping": {},
            "alias": {},
            "allow_bunqto": false,
            "amount": {},
            "attachment": [
              {}
            ],
            "balance_after_mutation": {},
            "batch_id": 0,
            "bunqto_expiry": "",
            "bunqto_share_url": "",
            "bunqto_status": "",
            "bunqto_sub_status": "",
            "bunqto_time_responded": "",
            "counterparty_alias": {},
            "created": "",
            "description": "",
            "geolocation": {},
            "id": 0,
            "merchant_reference": "",
            "monetary_account_id": 0,
            "payment_auto_allocate_instance": {
              "created": "",
              "error_message": [],
              "id": 0,
              "payment_auto_allocate_id": 0,
              "payment_batch": {
                "payments": {
                  "Payment": []
                }
              },
              "payment_id": 0,
              "status": "",
              "updated": ""
            },
            "request_reference_split_the_bill": [
              {}
            ],
            "scheduled_id": 0,
            "sub_type": "",
            "type": "",
            "updated": ""
          },
          "PaymentBatch": {}
        },
        "recurrence_size": 0,
        "recurrence_unit": "",
        "status": "",
        "time_end": "",
        "time_start": ""
      },
      "status": ""
    },
    "MasterCardAction": {
      "alias": {},
      "all_mastercard_action_refund": [
        {
          "additional_information": {
            "attachment": [
              {
                "id": 0
              }
            ],
            "category": "",
            "comment": "",
            "reason": "",
            "terms_and_conditions": ""
          },
          "alias": {},
          "amount": {},
          "attachment": [
            {}
          ],
          "category": "",
          "comment": "",
          "counterparty_alias": {},
          "created": "",
          "description": "",
          "id": 0,
          "label_card": {
            "expiry_date": "",
            "label_user": {},
            "second_line": "",
            "status": "",
            "type": "",
            "uuid": ""
          },
          "label_user_creator": {},
          "mastercard_action_id": 0,
          "reason": "",
          "reference_mastercard_action_event": [
            {
              "event_id": 0
            }
          ],
          "status": "",
          "status_description": "",
          "status_description_translated": "",
          "status_together_url": "",
          "sub_type": "",
          "terms_and_conditions": "",
          "time_refund": "",
          "type": "",
          "updated": ""
        }
      ],
      "amount_billing": {},
      "amount_converted": {},
      "amount_fee": {},
      "amount_local": {},
      "amount_original_billing": {},
      "amount_original_local": {},
      "applied_limit": "",
      "authorisation_status": "",
      "authorisation_type": "",
      "card_authorisation_id_response": "",
      "card_id": 0,
      "city": "",
      "clearing_expiry_time": "",
      "clearing_status": "",
      "counterparty_alias": {},
      "decision": "",
      "decision_description": "",
      "decision_description_translated": "",
      "decision_together_url": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "id": 0,
      "label_card": {},
      "maturity_date": "",
      "monetary_account_id": 0,
      "pan_entry_mode_user": "",
      "payment_status": "",
      "pos_card_holder_presence": "",
      "pos_card_presence": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "reservation_expiry_time": "",
      "secure_code_id": 0,
      "settlement_status": "",
      "token_status": "",
      "wallet_provider_id": ""
    },
    "Payment": {},
    "PaymentBatch": {},
    "RequestResponse": {
      "address_billing": {},
      "address_shipping": {},
      "alias": {},
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "content_type": "",
          "description": "",
          "urls": [
            {
              "type": "",
              "url": ""
            }
          ]
        }
      ],
      "counterparty_alias": {},
      "created": "",
      "credit_scheme_identifier": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "mandate_identifier": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "require_address": "",
      "status": "",
      "sub_type": "",
      "time_expiry": "",
      "time_refund_requested": "",
      "time_refunded": "",
      "time_responded": "",
      "type": "",
      "updated": "",
      "user_refund_requested": {}
    },
    "ScheduleInstance": {
      "error_message": [],
      "request_reference_split_the_bill": [
        {}
      ],
      "result_object": {
        "Payment": {},
        "PaymentBatch": {}
      },
      "scheduled_object": {},
      "state": "",
      "time_end": "",
      "time_start": ""
    },
    "TransferwisePayment": {
      "alias": {},
      "amount_source": {},
      "amount_target": {},
      "counterparty_alias": {},
      "monetary_account_id": "",
      "pay_in_reference": "",
      "quote": {
        "amount_fee": {},
        "amount_source": {},
        "amount_target": {},
        "created": "",
        "currency_source": "",
        "currency_target": "",
        "id": 0,
        "quote_id": "",
        "rate": "",
        "time_delivery_estimate": "",
        "time_expiry": "",
        "updated": ""
      },
      "rate": "",
      "recipient_id": "",
      "reference": "",
      "status": "",
      "status_transferwise": "",
      "status_transferwise_issue": "",
      "sub_status": "",
      "time_delivery_estimate": ""
    },
    "WhitelistResult": {
      "error_message": [],
      "id": 0,
      "monetary_account_paying_id": 0,
      "object": {
        "draftPayment": {},
        "id": 0,
        "requestResponse": {}
      },
      "request_reference_split_the_bill": [
        {}
      ],
      "status": "",
      "sub_status": "",
      "whitelist": {}
    }
  },
  "require_address": "",
  "scheduled_id": 0,
  "status": "",
  "time_expiry": "",
  "time_responded": "",
  "updated": "",
  "user_alias_created": {},
  "user_alias_revoked": {},
  "want_tip": false
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"allow_amount_higher\": false,\n  \"allow_amount_lower\": false,\n  \"allow_bunqme\": false,\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"id\": 0\n    }\n  ],\n  \"batch_id\": 0,\n  \"bunqme_share_url\": \"\",\n  \"counterparty_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {},\n      \"alias\": {},\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {},\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {},\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"require_address\": \"\",\n  \"scheduled_id\": 0,\n  \"status\": \"\",\n  \"time_expiry\": \"\",\n  \"time_responded\": \"\",\n  \"updated\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {},\n  \"want_tip\": false\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry" {:headers {:user-agent ""
                                                                                                                        :x-bunq-client-authentication ""}
                                                                                                              :content-type :json
                                                                                                              :form-params {:address_billing {:city ""
                                                                                                                                              :country ""
                                                                                                                                              :extra ""
                                                                                                                                              :house_number ""
                                                                                                                                              :is_user_address_updated false
                                                                                                                                              :mailbox_name ""
                                                                                                                                              :po_box ""
                                                                                                                                              :postal_code ""
                                                                                                                                              :province ""
                                                                                                                                              :street ""}
                                                                                                                            :address_shipping {}
                                                                                                                            :allow_amount_higher false
                                                                                                                            :allow_amount_lower false
                                                                                                                            :allow_bunqme false
                                                                                                                            :amount_inquired {:currency ""
                                                                                                                                              :value ""}
                                                                                                                            :amount_responded {}
                                                                                                                            :attachment [{:id 0}]
                                                                                                                            :batch_id 0
                                                                                                                            :bunqme_share_url ""
                                                                                                                            :counterparty_alias {:avatar {:anchor_uuid ""
                                                                                                                                                          :image [{:attachment_public_uuid ""
                                                                                                                                                                   :content_type ""
                                                                                                                                                                   :height 0
                                                                                                                                                                   :width 0}]
                                                                                                                                                          :style ""
                                                                                                                                                          :uuid ""}
                                                                                                                                                 :bunq_me {:name ""
                                                                                                                                                           :service ""
                                                                                                                                                           :type ""
                                                                                                                                                           :value ""}
                                                                                                                                                 :country ""
                                                                                                                                                 :display_name ""
                                                                                                                                                 :iban ""
                                                                                                                                                 :is_light false
                                                                                                                                                 :label_user {:avatar {}
                                                                                                                                                              :country ""
                                                                                                                                                              :display_name ""
                                                                                                                                                              :public_nick_name ""
                                                                                                                                                              :uuid ""}
                                                                                                                                                 :merchant_category_code ""
                                                                                                                                                 :swift_account_number ""
                                                                                                                                                 :swift_bic ""
                                                                                                                                                 :transferwise_account_number ""
                                                                                                                                                 :transferwise_bank_code ""}
                                                                                                                            :created ""
                                                                                                                            :description ""
                                                                                                                            :event_id 0
                                                                                                                            :geolocation {:altitude 0
                                                                                                                                          :latitude 0
                                                                                                                                          :longitude 0
                                                                                                                                          :radius 0}
                                                                                                                            :id 0
                                                                                                                            :merchant_reference ""
                                                                                                                            :minimum_age 0
                                                                                                                            :monetary_account_id 0
                                                                                                                            :redirect_url ""
                                                                                                                            :reference_split_the_bill {:BillingInvoice {:address {}
                                                                                                                                                                        :alias {}
                                                                                                                                                                        :category ""
                                                                                                                                                                        :chamber_of_commerce_number ""
                                                                                                                                                                        :counterparty_address {}
                                                                                                                                                                        :counterparty_alias {}
                                                                                                                                                                        :created ""
                                                                                                                                                                        :description ""
                                                                                                                                                                        :external_url ""
                                                                                                                                                                        :group [{:instance_description ""
                                                                                                                                                                                 :item [{:billing_date ""
                                                                                                                                                                                         :id 0
                                                                                                                                                                                         :quantity 0
                                                                                                                                                                                         :total_vat_exclusive {}
                                                                                                                                                                                         :total_vat_inclusive {}
                                                                                                                                                                                         :type_description ""
                                                                                                                                                                                         :type_description_translated ""
                                                                                                                                                                                         :unit_vat_exclusive {}
                                                                                                                                                                                         :unit_vat_inclusive {}
                                                                                                                                                                                         :vat 0}]
                                                                                                                                                                                 :product_vat_exclusive {}
                                                                                                                                                                                 :product_vat_inclusive {}
                                                                                                                                                                                 :type ""
                                                                                                                                                                                 :type_description ""
                                                                                                                                                                                 :type_description_translated ""}]
                                                                                                                                                                        :id 0
                                                                                                                                                                        :invoice_date ""
                                                                                                                                                                        :invoice_number ""
                                                                                                                                                                        :request_reference_split_the_bill [{:id 0
                                                                                                                                                                                                            :type ""}]
                                                                                                                                                                        :status ""
                                                                                                                                                                        :total_vat {}
                                                                                                                                                                        :total_vat_exclusive {}
                                                                                                                                                                        :total_vat_inclusive {}
                                                                                                                                                                        :updated ""
                                                                                                                                                                        :vat_number ""}
                                                                                                                                                       :DraftPayment {:entries [{:alias {}
                                                                                                                                                                                 :amount {}
                                                                                                                                                                                 :attachment [{:id 0
                                                                                                                                                                                               :monetary_account_id 0}]
                                                                                                                                                                                 :counterparty_alias {}
                                                                                                                                                                                 :description ""
                                                                                                                                                                                 :id 0
                                                                                                                                                                                 :merchant_reference ""
                                                                                                                                                                                 :type ""}]
                                                                                                                                                                      :number_of_required_accepts 0
                                                                                                                                                                      :previous_updated_timestamp ""
                                                                                                                                                                      :schedule {:object {:Payment {:address_billing {}
                                                                                                                                                                                                    :address_shipping {}
                                                                                                                                                                                                    :alias {}
                                                                                                                                                                                                    :allow_bunqto false
                                                                                                                                                                                                    :amount {}
                                                                                                                                                                                                    :attachment [{}]
                                                                                                                                                                                                    :balance_after_mutation {}
                                                                                                                                                                                                    :batch_id 0
                                                                                                                                                                                                    :bunqto_expiry ""
                                                                                                                                                                                                    :bunqto_share_url ""
                                                                                                                                                                                                    :bunqto_status ""
                                                                                                                                                                                                    :bunqto_sub_status ""
                                                                                                                                                                                                    :bunqto_time_responded ""
                                                                                                                                                                                                    :counterparty_alias {}
                                                                                                                                                                                                    :created ""
                                                                                                                                                                                                    :description ""
                                                                                                                                                                                                    :geolocation {}
                                                                                                                                                                                                    :id 0
                                                                                                                                                                                                    :merchant_reference ""
                                                                                                                                                                                                    :monetary_account_id 0
                                                                                                                                                                                                    :payment_auto_allocate_instance {:created ""
                                                                                                                                                                                                                                     :error_message []
                                                                                                                                                                                                                                     :id 0
                                                                                                                                                                                                                                     :payment_auto_allocate_id 0
                                                                                                                                                                                                                                     :payment_batch {:payments {:Payment []}}
                                                                                                                                                                                                                                     :payment_id 0
                                                                                                                                                                                                                                     :status ""
                                                                                                                                                                                                                                     :updated ""}
                                                                                                                                                                                                    :request_reference_split_the_bill [{}]
                                                                                                                                                                                                    :scheduled_id 0
                                                                                                                                                                                                    :sub_type ""
                                                                                                                                                                                                    :type ""
                                                                                                                                                                                                    :updated ""}
                                                                                                                                                                                          :PaymentBatch {}}
                                                                                                                                                                                 :recurrence_size 0
                                                                                                                                                                                 :recurrence_unit ""
                                                                                                                                                                                 :status ""
                                                                                                                                                                                 :time_end ""
                                                                                                                                                                                 :time_start ""}
                                                                                                                                                                      :status ""}
                                                                                                                                                       :MasterCardAction {:alias {}
                                                                                                                                                                          :all_mastercard_action_refund [{:additional_information {:attachment [{:id 0}]
                                                                                                                                                                                                                                   :category ""
                                                                                                                                                                                                                                   :comment ""
                                                                                                                                                                                                                                   :reason ""
                                                                                                                                                                                                                                   :terms_and_conditions ""}
                                                                                                                                                                                                          :alias {}
                                                                                                                                                                                                          :amount {}
                                                                                                                                                                                                          :attachment [{}]
                                                                                                                                                                                                          :category ""
                                                                                                                                                                                                          :comment ""
                                                                                                                                                                                                          :counterparty_alias {}
                                                                                                                                                                                                          :created ""
                                                                                                                                                                                                          :description ""
                                                                                                                                                                                                          :id 0
                                                                                                                                                                                                          :label_card {:expiry_date ""
                                                                                                                                                                                                                       :label_user {}
                                                                                                                                                                                                                       :second_line ""
                                                                                                                                                                                                                       :status ""
                                                                                                                                                                                                                       :type ""
                                                                                                                                                                                                                       :uuid ""}
                                                                                                                                                                                                          :label_user_creator {}
                                                                                                                                                                                                          :mastercard_action_id 0
                                                                                                                                                                                                          :reason ""
                                                                                                                                                                                                          :reference_mastercard_action_event [{:event_id 0}]
                                                                                                                                                                                                          :status ""
                                                                                                                                                                                                          :status_description ""
                                                                                                                                                                                                          :status_description_translated ""
                                                                                                                                                                                                          :status_together_url ""
                                                                                                                                                                                                          :sub_type ""
                                                                                                                                                                                                          :terms_and_conditions ""
                                                                                                                                                                                                          :time_refund ""
                                                                                                                                                                                                          :type ""
                                                                                                                                                                                                          :updated ""}]
                                                                                                                                                                          :amount_billing {}
                                                                                                                                                                          :amount_converted {}
                                                                                                                                                                          :amount_fee {}
                                                                                                                                                                          :amount_local {}
                                                                                                                                                                          :amount_original_billing {}
                                                                                                                                                                          :amount_original_local {}
                                                                                                                                                                          :applied_limit ""
                                                                                                                                                                          :authorisation_status ""
                                                                                                                                                                          :authorisation_type ""
                                                                                                                                                                          :card_authorisation_id_response ""
                                                                                                                                                                          :card_id 0
                                                                                                                                                                          :city ""
                                                                                                                                                                          :clearing_expiry_time ""
                                                                                                                                                                          :clearing_status ""
                                                                                                                                                                          :counterparty_alias {}
                                                                                                                                                                          :decision ""
                                                                                                                                                                          :decision_description ""
                                                                                                                                                                          :decision_description_translated ""
                                                                                                                                                                          :decision_together_url ""
                                                                                                                                                                          :description ""
                                                                                                                                                                          :eligible_whitelist_id 0
                                                                                                                                                                          :id 0
                                                                                                                                                                          :label_card {}
                                                                                                                                                                          :maturity_date ""
                                                                                                                                                                          :monetary_account_id 0
                                                                                                                                                                          :pan_entry_mode_user ""
                                                                                                                                                                          :payment_status ""
                                                                                                                                                                          :pos_card_holder_presence ""
                                                                                                                                                                          :pos_card_presence ""
                                                                                                                                                                          :request_reference_split_the_bill [{}]
                                                                                                                                                                          :reservation_expiry_time ""
                                                                                                                                                                          :secure_code_id 0
                                                                                                                                                                          :settlement_status ""
                                                                                                                                                                          :token_status ""
                                                                                                                                                                          :wallet_provider_id ""}
                                                                                                                                                       :Payment {}
                                                                                                                                                       :PaymentBatch {}
                                                                                                                                                       :RequestResponse {:address_billing {}
                                                                                                                                                                         :address_shipping {}
                                                                                                                                                                         :alias {}
                                                                                                                                                                         :amount_inquired {}
                                                                                                                                                                         :amount_responded {}
                                                                                                                                                                         :attachment [{:content_type ""
                                                                                                                                                                                       :description ""
                                                                                                                                                                                       :urls [{:type ""
                                                                                                                                                                                               :url ""}]}]
                                                                                                                                                                         :counterparty_alias {}
                                                                                                                                                                         :created ""
                                                                                                                                                                         :credit_scheme_identifier ""
                                                                                                                                                                         :description ""
                                                                                                                                                                         :eligible_whitelist_id 0
                                                                                                                                                                         :event_id 0
                                                                                                                                                                         :geolocation {}
                                                                                                                                                                         :id 0
                                                                                                                                                                         :mandate_identifier ""
                                                                                                                                                                         :minimum_age 0
                                                                                                                                                                         :monetary_account_id 0
                                                                                                                                                                         :redirect_url ""
                                                                                                                                                                         :request_reference_split_the_bill [{}]
                                                                                                                                                                         :require_address ""
                                                                                                                                                                         :status ""
                                                                                                                                                                         :sub_type ""
                                                                                                                                                                         :time_expiry ""
                                                                                                                                                                         :time_refund_requested ""
                                                                                                                                                                         :time_refunded ""
                                                                                                                                                                         :time_responded ""
                                                                                                                                                                         :type ""
                                                                                                                                                                         :updated ""
                                                                                                                                                                         :user_refund_requested {}}
                                                                                                                                                       :ScheduleInstance {:error_message []
                                                                                                                                                                          :request_reference_split_the_bill [{}]
                                                                                                                                                                          :result_object {:Payment {}
                                                                                                                                                                                          :PaymentBatch {}}
                                                                                                                                                                          :scheduled_object {}
                                                                                                                                                                          :state ""
                                                                                                                                                                          :time_end ""
                                                                                                                                                                          :time_start ""}
                                                                                                                                                       :TransferwisePayment {:alias {}
                                                                                                                                                                             :amount_source {}
                                                                                                                                                                             :amount_target {}
                                                                                                                                                                             :counterparty_alias {}
                                                                                                                                                                             :monetary_account_id ""
                                                                                                                                                                             :pay_in_reference ""
                                                                                                                                                                             :quote {:amount_fee {}
                                                                                                                                                                                     :amount_source {}
                                                                                                                                                                                     :amount_target {}
                                                                                                                                                                                     :created ""
                                                                                                                                                                                     :currency_source ""
                                                                                                                                                                                     :currency_target ""
                                                                                                                                                                                     :id 0
                                                                                                                                                                                     :quote_id ""
                                                                                                                                                                                     :rate ""
                                                                                                                                                                                     :time_delivery_estimate ""
                                                                                                                                                                                     :time_expiry ""
                                                                                                                                                                                     :updated ""}
                                                                                                                                                                             :rate ""
                                                                                                                                                                             :recipient_id ""
                                                                                                                                                                             :reference ""
                                                                                                                                                                             :status ""
                                                                                                                                                                             :status_transferwise ""
                                                                                                                                                                             :status_transferwise_issue ""
                                                                                                                                                                             :sub_status ""
                                                                                                                                                                             :time_delivery_estimate ""}
                                                                                                                                                       :WhitelistResult {:error_message []
                                                                                                                                                                         :id 0
                                                                                                                                                                         :monetary_account_paying_id 0
                                                                                                                                                                         :object {:draftPayment {}
                                                                                                                                                                                  :id 0
                                                                                                                                                                                  :requestResponse {}}
                                                                                                                                                                         :request_reference_split_the_bill [{}]
                                                                                                                                                                         :status ""
                                                                                                                                                                         :sub_status ""
                                                                                                                                                                         :whitelist {}}}
                                                                                                                            :require_address ""
                                                                                                                            :scheduled_id 0
                                                                                                                            :status ""
                                                                                                                            :time_expiry ""
                                                                                                                            :time_responded ""
                                                                                                                            :updated ""
                                                                                                                            :user_alias_created {}
                                                                                                                            :user_alias_revoked {}
                                                                                                                            :want_tip false}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"allow_amount_higher\": false,\n  \"allow_amount_lower\": false,\n  \"allow_bunqme\": false,\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"id\": 0\n    }\n  ],\n  \"batch_id\": 0,\n  \"bunqme_share_url\": \"\",\n  \"counterparty_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {},\n      \"alias\": {},\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {},\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {},\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"require_address\": \"\",\n  \"scheduled_id\": 0,\n  \"status\": \"\",\n  \"time_expiry\": \"\",\n  \"time_responded\": \"\",\n  \"updated\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {},\n  \"want_tip\": false\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"allow_amount_higher\": false,\n  \"allow_amount_lower\": false,\n  \"allow_bunqme\": false,\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"id\": 0\n    }\n  ],\n  \"batch_id\": 0,\n  \"bunqme_share_url\": \"\",\n  \"counterparty_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {},\n      \"alias\": {},\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {},\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {},\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"require_address\": \"\",\n  \"scheduled_id\": 0,\n  \"status\": \"\",\n  \"time_expiry\": \"\",\n  \"time_responded\": \"\",\n  \"updated\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {},\n  \"want_tip\": false\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"allow_amount_higher\": false,\n  \"allow_amount_lower\": false,\n  \"allow_bunqme\": false,\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"id\": 0\n    }\n  ],\n  \"batch_id\": 0,\n  \"bunqme_share_url\": \"\",\n  \"counterparty_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {},\n      \"alias\": {},\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {},\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {},\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"require_address\": \"\",\n  \"scheduled_id\": 0,\n  \"status\": \"\",\n  \"time_expiry\": \"\",\n  \"time_responded\": \"\",\n  \"updated\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {},\n  \"want_tip\": false\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry"

	payload := strings.NewReader("{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"allow_amount_higher\": false,\n  \"allow_amount_lower\": false,\n  \"allow_bunqme\": false,\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"id\": 0\n    }\n  ],\n  \"batch_id\": 0,\n  \"bunqme_share_url\": \"\",\n  \"counterparty_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {},\n      \"alias\": {},\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {},\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {},\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"require_address\": \"\",\n  \"scheduled_id\": 0,\n  \"status\": \"\",\n  \"time_expiry\": \"\",\n  \"time_responded\": \"\",\n  \"updated\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {},\n  \"want_tip\": false\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 10061

{
  "address_billing": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_shipping": {},
  "allow_amount_higher": false,
  "allow_amount_lower": false,
  "allow_bunqme": false,
  "amount_inquired": {
    "currency": "",
    "value": ""
  },
  "amount_responded": {},
  "attachment": [
    {
      "id": 0
    }
  ],
  "batch_id": 0,
  "bunqme_share_url": "",
  "counterparty_alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "created": "",
  "description": "",
  "event_id": 0,
  "geolocation": {
    "altitude": 0,
    "latitude": 0,
    "longitude": 0,
    "radius": 0
  },
  "id": 0,
  "merchant_reference": "",
  "minimum_age": 0,
  "monetary_account_id": 0,
  "redirect_url": "",
  "reference_split_the_bill": {
    "BillingInvoice": {
      "address": {},
      "alias": {},
      "category": "",
      "chamber_of_commerce_number": "",
      "counterparty_address": {},
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "external_url": "",
      "group": [
        {
          "instance_description": "",
          "item": [
            {
              "billing_date": "",
              "id": 0,
              "quantity": 0,
              "total_vat_exclusive": {},
              "total_vat_inclusive": {},
              "type_description": "",
              "type_description_translated": "",
              "unit_vat_exclusive": {},
              "unit_vat_inclusive": {},
              "vat": 0
            }
          ],
          "product_vat_exclusive": {},
          "product_vat_inclusive": {},
          "type": "",
          "type_description": "",
          "type_description_translated": ""
        }
      ],
      "id": 0,
      "invoice_date": "",
      "invoice_number": "",
      "request_reference_split_the_bill": [
        {
          "id": 0,
          "type": ""
        }
      ],
      "status": "",
      "total_vat": {},
      "total_vat_exclusive": {},
      "total_vat_inclusive": {},
      "updated": "",
      "vat_number": ""
    },
    "DraftPayment": {
      "entries": [
        {
          "alias": {},
          "amount": {},
          "attachment": [
            {
              "id": 0,
              "monetary_account_id": 0
            }
          ],
          "counterparty_alias": {},
          "description": "",
          "id": 0,
          "merchant_reference": "",
          "type": ""
        }
      ],
      "number_of_required_accepts": 0,
      "previous_updated_timestamp": "",
      "schedule": {
        "object": {
          "Payment": {
            "address_billing": {},
            "address_shipping": {},
            "alias": {},
            "allow_bunqto": false,
            "amount": {},
            "attachment": [
              {}
            ],
            "balance_after_mutation": {},
            "batch_id": 0,
            "bunqto_expiry": "",
            "bunqto_share_url": "",
            "bunqto_status": "",
            "bunqto_sub_status": "",
            "bunqto_time_responded": "",
            "counterparty_alias": {},
            "created": "",
            "description": "",
            "geolocation": {},
            "id": 0,
            "merchant_reference": "",
            "monetary_account_id": 0,
            "payment_auto_allocate_instance": {
              "created": "",
              "error_message": [],
              "id": 0,
              "payment_auto_allocate_id": 0,
              "payment_batch": {
                "payments": {
                  "Payment": []
                }
              },
              "payment_id": 0,
              "status": "",
              "updated": ""
            },
            "request_reference_split_the_bill": [
              {}
            ],
            "scheduled_id": 0,
            "sub_type": "",
            "type": "",
            "updated": ""
          },
          "PaymentBatch": {}
        },
        "recurrence_size": 0,
        "recurrence_unit": "",
        "status": "",
        "time_end": "",
        "time_start": ""
      },
      "status": ""
    },
    "MasterCardAction": {
      "alias": {},
      "all_mastercard_action_refund": [
        {
          "additional_information": {
            "attachment": [
              {
                "id": 0
              }
            ],
            "category": "",
            "comment": "",
            "reason": "",
            "terms_and_conditions": ""
          },
          "alias": {},
          "amount": {},
          "attachment": [
            {}
          ],
          "category": "",
          "comment": "",
          "counterparty_alias": {},
          "created": "",
          "description": "",
          "id": 0,
          "label_card": {
            "expiry_date": "",
            "label_user": {},
            "second_line": "",
            "status": "",
            "type": "",
            "uuid": ""
          },
          "label_user_creator": {},
          "mastercard_action_id": 0,
          "reason": "",
          "reference_mastercard_action_event": [
            {
              "event_id": 0
            }
          ],
          "status": "",
          "status_description": "",
          "status_description_translated": "",
          "status_together_url": "",
          "sub_type": "",
          "terms_and_conditions": "",
          "time_refund": "",
          "type": "",
          "updated": ""
        }
      ],
      "amount_billing": {},
      "amount_converted": {},
      "amount_fee": {},
      "amount_local": {},
      "amount_original_billing": {},
      "amount_original_local": {},
      "applied_limit": "",
      "authorisation_status": "",
      "authorisation_type": "",
      "card_authorisation_id_response": "",
      "card_id": 0,
      "city": "",
      "clearing_expiry_time": "",
      "clearing_status": "",
      "counterparty_alias": {},
      "decision": "",
      "decision_description": "",
      "decision_description_translated": "",
      "decision_together_url": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "id": 0,
      "label_card": {},
      "maturity_date": "",
      "monetary_account_id": 0,
      "pan_entry_mode_user": "",
      "payment_status": "",
      "pos_card_holder_presence": "",
      "pos_card_presence": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "reservation_expiry_time": "",
      "secure_code_id": 0,
      "settlement_status": "",
      "token_status": "",
      "wallet_provider_id": ""
    },
    "Payment": {},
    "PaymentBatch": {},
    "RequestResponse": {
      "address_billing": {},
      "address_shipping": {},
      "alias": {},
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "content_type": "",
          "description": "",
          "urls": [
            {
              "type": "",
              "url": ""
            }
          ]
        }
      ],
      "counterparty_alias": {},
      "created": "",
      "credit_scheme_identifier": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "mandate_identifier": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "require_address": "",
      "status": "",
      "sub_type": "",
      "time_expiry": "",
      "time_refund_requested": "",
      "time_refunded": "",
      "time_responded": "",
      "type": "",
      "updated": "",
      "user_refund_requested": {}
    },
    "ScheduleInstance": {
      "error_message": [],
      "request_reference_split_the_bill": [
        {}
      ],
      "result_object": {
        "Payment": {},
        "PaymentBatch": {}
      },
      "scheduled_object": {},
      "state": "",
      "time_end": "",
      "time_start": ""
    },
    "TransferwisePayment": {
      "alias": {},
      "amount_source": {},
      "amount_target": {},
      "counterparty_alias": {},
      "monetary_account_id": "",
      "pay_in_reference": "",
      "quote": {
        "amount_fee": {},
        "amount_source": {},
        "amount_target": {},
        "created": "",
        "currency_source": "",
        "currency_target": "",
        "id": 0,
        "quote_id": "",
        "rate": "",
        "time_delivery_estimate": "",
        "time_expiry": "",
        "updated": ""
      },
      "rate": "",
      "recipient_id": "",
      "reference": "",
      "status": "",
      "status_transferwise": "",
      "status_transferwise_issue": "",
      "sub_status": "",
      "time_delivery_estimate": ""
    },
    "WhitelistResult": {
      "error_message": [],
      "id": 0,
      "monetary_account_paying_id": 0,
      "object": {
        "draftPayment": {},
        "id": 0,
        "requestResponse": {}
      },
      "request_reference_split_the_bill": [
        {}
      ],
      "status": "",
      "sub_status": "",
      "whitelist": {}
    }
  },
  "require_address": "",
  "scheduled_id": 0,
  "status": "",
  "time_expiry": "",
  "time_responded": "",
  "updated": "",
  "user_alias_created": {},
  "user_alias_revoked": {},
  "want_tip": false
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"allow_amount_higher\": false,\n  \"allow_amount_lower\": false,\n  \"allow_bunqme\": false,\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"id\": 0\n    }\n  ],\n  \"batch_id\": 0,\n  \"bunqme_share_url\": \"\",\n  \"counterparty_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {},\n      \"alias\": {},\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {},\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {},\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"require_address\": \"\",\n  \"scheduled_id\": 0,\n  \"status\": \"\",\n  \"time_expiry\": \"\",\n  \"time_responded\": \"\",\n  \"updated\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {},\n  \"want_tip\": false\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"allow_amount_higher\": false,\n  \"allow_amount_lower\": false,\n  \"allow_bunqme\": false,\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"id\": 0\n    }\n  ],\n  \"batch_id\": 0,\n  \"bunqme_share_url\": \"\",\n  \"counterparty_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {},\n      \"alias\": {},\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {},\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {},\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"require_address\": \"\",\n  \"scheduled_id\": 0,\n  \"status\": \"\",\n  \"time_expiry\": \"\",\n  \"time_responded\": \"\",\n  \"updated\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {},\n  \"want_tip\": false\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"allow_amount_higher\": false,\n  \"allow_amount_lower\": false,\n  \"allow_bunqme\": false,\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"id\": 0\n    }\n  ],\n  \"batch_id\": 0,\n  \"bunqme_share_url\": \"\",\n  \"counterparty_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {},\n      \"alias\": {},\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {},\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {},\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"require_address\": \"\",\n  \"scheduled_id\": 0,\n  \"status\": \"\",\n  \"time_expiry\": \"\",\n  \"time_responded\": \"\",\n  \"updated\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {},\n  \"want_tip\": false\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"allow_amount_higher\": false,\n  \"allow_amount_lower\": false,\n  \"allow_bunqme\": false,\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"id\": 0\n    }\n  ],\n  \"batch_id\": 0,\n  \"bunqme_share_url\": \"\",\n  \"counterparty_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {},\n      \"alias\": {},\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {},\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {},\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"require_address\": \"\",\n  \"scheduled_id\": 0,\n  \"status\": \"\",\n  \"time_expiry\": \"\",\n  \"time_responded\": \"\",\n  \"updated\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {},\n  \"want_tip\": false\n}")
  .asString();
const data = JSON.stringify({
  address_billing: {
    city: '',
    country: '',
    extra: '',
    house_number: '',
    is_user_address_updated: false,
    mailbox_name: '',
    po_box: '',
    postal_code: '',
    province: '',
    street: ''
  },
  address_shipping: {},
  allow_amount_higher: false,
  allow_amount_lower: false,
  allow_bunqme: false,
  amount_inquired: {
    currency: '',
    value: ''
  },
  amount_responded: {},
  attachment: [
    {
      id: 0
    }
  ],
  batch_id: 0,
  bunqme_share_url: '',
  counterparty_alias: {
    avatar: {
      anchor_uuid: '',
      image: [
        {
          attachment_public_uuid: '',
          content_type: '',
          height: 0,
          width: 0
        }
      ],
      style: '',
      uuid: ''
    },
    bunq_me: {
      name: '',
      service: '',
      type: '',
      value: ''
    },
    country: '',
    display_name: '',
    iban: '',
    is_light: false,
    label_user: {
      avatar: {},
      country: '',
      display_name: '',
      public_nick_name: '',
      uuid: ''
    },
    merchant_category_code: '',
    swift_account_number: '',
    swift_bic: '',
    transferwise_account_number: '',
    transferwise_bank_code: ''
  },
  created: '',
  description: '',
  event_id: 0,
  geolocation: {
    altitude: 0,
    latitude: 0,
    longitude: 0,
    radius: 0
  },
  id: 0,
  merchant_reference: '',
  minimum_age: 0,
  monetary_account_id: 0,
  redirect_url: '',
  reference_split_the_bill: {
    BillingInvoice: {
      address: {},
      alias: {},
      category: '',
      chamber_of_commerce_number: '',
      counterparty_address: {},
      counterparty_alias: {},
      created: '',
      description: '',
      external_url: '',
      group: [
        {
          instance_description: '',
          item: [
            {
              billing_date: '',
              id: 0,
              quantity: 0,
              total_vat_exclusive: {},
              total_vat_inclusive: {},
              type_description: '',
              type_description_translated: '',
              unit_vat_exclusive: {},
              unit_vat_inclusive: {},
              vat: 0
            }
          ],
          product_vat_exclusive: {},
          product_vat_inclusive: {},
          type: '',
          type_description: '',
          type_description_translated: ''
        }
      ],
      id: 0,
      invoice_date: '',
      invoice_number: '',
      request_reference_split_the_bill: [
        {
          id: 0,
          type: ''
        }
      ],
      status: '',
      total_vat: {},
      total_vat_exclusive: {},
      total_vat_inclusive: {},
      updated: '',
      vat_number: ''
    },
    DraftPayment: {
      entries: [
        {
          alias: {},
          amount: {},
          attachment: [
            {
              id: 0,
              monetary_account_id: 0
            }
          ],
          counterparty_alias: {},
          description: '',
          id: 0,
          merchant_reference: '',
          type: ''
        }
      ],
      number_of_required_accepts: 0,
      previous_updated_timestamp: '',
      schedule: {
        object: {
          Payment: {
            address_billing: {},
            address_shipping: {},
            alias: {},
            allow_bunqto: false,
            amount: {},
            attachment: [
              {}
            ],
            balance_after_mutation: {},
            batch_id: 0,
            bunqto_expiry: '',
            bunqto_share_url: '',
            bunqto_status: '',
            bunqto_sub_status: '',
            bunqto_time_responded: '',
            counterparty_alias: {},
            created: '',
            description: '',
            geolocation: {},
            id: 0,
            merchant_reference: '',
            monetary_account_id: 0,
            payment_auto_allocate_instance: {
              created: '',
              error_message: [],
              id: 0,
              payment_auto_allocate_id: 0,
              payment_batch: {
                payments: {
                  Payment: []
                }
              },
              payment_id: 0,
              status: '',
              updated: ''
            },
            request_reference_split_the_bill: [
              {}
            ],
            scheduled_id: 0,
            sub_type: '',
            type: '',
            updated: ''
          },
          PaymentBatch: {}
        },
        recurrence_size: 0,
        recurrence_unit: '',
        status: '',
        time_end: '',
        time_start: ''
      },
      status: ''
    },
    MasterCardAction: {
      alias: {},
      all_mastercard_action_refund: [
        {
          additional_information: {
            attachment: [
              {
                id: 0
              }
            ],
            category: '',
            comment: '',
            reason: '',
            terms_and_conditions: ''
          },
          alias: {},
          amount: {},
          attachment: [
            {}
          ],
          category: '',
          comment: '',
          counterparty_alias: {},
          created: '',
          description: '',
          id: 0,
          label_card: {
            expiry_date: '',
            label_user: {},
            second_line: '',
            status: '',
            type: '',
            uuid: ''
          },
          label_user_creator: {},
          mastercard_action_id: 0,
          reason: '',
          reference_mastercard_action_event: [
            {
              event_id: 0
            }
          ],
          status: '',
          status_description: '',
          status_description_translated: '',
          status_together_url: '',
          sub_type: '',
          terms_and_conditions: '',
          time_refund: '',
          type: '',
          updated: ''
        }
      ],
      amount_billing: {},
      amount_converted: {},
      amount_fee: {},
      amount_local: {},
      amount_original_billing: {},
      amount_original_local: {},
      applied_limit: '',
      authorisation_status: '',
      authorisation_type: '',
      card_authorisation_id_response: '',
      card_id: 0,
      city: '',
      clearing_expiry_time: '',
      clearing_status: '',
      counterparty_alias: {},
      decision: '',
      decision_description: '',
      decision_description_translated: '',
      decision_together_url: '',
      description: '',
      eligible_whitelist_id: 0,
      id: 0,
      label_card: {},
      maturity_date: '',
      monetary_account_id: 0,
      pan_entry_mode_user: '',
      payment_status: '',
      pos_card_holder_presence: '',
      pos_card_presence: '',
      request_reference_split_the_bill: [
        {}
      ],
      reservation_expiry_time: '',
      secure_code_id: 0,
      settlement_status: '',
      token_status: '',
      wallet_provider_id: ''
    },
    Payment: {},
    PaymentBatch: {},
    RequestResponse: {
      address_billing: {},
      address_shipping: {},
      alias: {},
      amount_inquired: {},
      amount_responded: {},
      attachment: [
        {
          content_type: '',
          description: '',
          urls: [
            {
              type: '',
              url: ''
            }
          ]
        }
      ],
      counterparty_alias: {},
      created: '',
      credit_scheme_identifier: '',
      description: '',
      eligible_whitelist_id: 0,
      event_id: 0,
      geolocation: {},
      id: 0,
      mandate_identifier: '',
      minimum_age: 0,
      monetary_account_id: 0,
      redirect_url: '',
      request_reference_split_the_bill: [
        {}
      ],
      require_address: '',
      status: '',
      sub_type: '',
      time_expiry: '',
      time_refund_requested: '',
      time_refunded: '',
      time_responded: '',
      type: '',
      updated: '',
      user_refund_requested: {}
    },
    ScheduleInstance: {
      error_message: [],
      request_reference_split_the_bill: [
        {}
      ],
      result_object: {
        Payment: {},
        PaymentBatch: {}
      },
      scheduled_object: {},
      state: '',
      time_end: '',
      time_start: ''
    },
    TransferwisePayment: {
      alias: {},
      amount_source: {},
      amount_target: {},
      counterparty_alias: {},
      monetary_account_id: '',
      pay_in_reference: '',
      quote: {
        amount_fee: {},
        amount_source: {},
        amount_target: {},
        created: '',
        currency_source: '',
        currency_target: '',
        id: 0,
        quote_id: '',
        rate: '',
        time_delivery_estimate: '',
        time_expiry: '',
        updated: ''
      },
      rate: '',
      recipient_id: '',
      reference: '',
      status: '',
      status_transferwise: '',
      status_transferwise_issue: '',
      sub_status: '',
      time_delivery_estimate: ''
    },
    WhitelistResult: {
      error_message: [],
      id: 0,
      monetary_account_paying_id: 0,
      object: {
        draftPayment: {},
        id: 0,
        requestResponse: {}
      },
      request_reference_split_the_bill: [
        {}
      ],
      status: '',
      sub_status: '',
      whitelist: {}
    }
  },
  require_address: '',
  scheduled_id: 0,
  status: '',
  time_expiry: '',
  time_responded: '',
  updated: '',
  user_alias_created: {},
  user_alias_revoked: {},
  want_tip: false
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    address_billing: {
      city: '',
      country: '',
      extra: '',
      house_number: '',
      is_user_address_updated: false,
      mailbox_name: '',
      po_box: '',
      postal_code: '',
      province: '',
      street: ''
    },
    address_shipping: {},
    allow_amount_higher: false,
    allow_amount_lower: false,
    allow_bunqme: false,
    amount_inquired: {currency: '', value: ''},
    amount_responded: {},
    attachment: [{id: 0}],
    batch_id: 0,
    bunqme_share_url: '',
    counterparty_alias: {
      avatar: {
        anchor_uuid: '',
        image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
        style: '',
        uuid: ''
      },
      bunq_me: {name: '', service: '', type: '', value: ''},
      country: '',
      display_name: '',
      iban: '',
      is_light: false,
      label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
      merchant_category_code: '',
      swift_account_number: '',
      swift_bic: '',
      transferwise_account_number: '',
      transferwise_bank_code: ''
    },
    created: '',
    description: '',
    event_id: 0,
    geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
    id: 0,
    merchant_reference: '',
    minimum_age: 0,
    monetary_account_id: 0,
    redirect_url: '',
    reference_split_the_bill: {
      BillingInvoice: {
        address: {},
        alias: {},
        category: '',
        chamber_of_commerce_number: '',
        counterparty_address: {},
        counterparty_alias: {},
        created: '',
        description: '',
        external_url: '',
        group: [
          {
            instance_description: '',
            item: [
              {
                billing_date: '',
                id: 0,
                quantity: 0,
                total_vat_exclusive: {},
                total_vat_inclusive: {},
                type_description: '',
                type_description_translated: '',
                unit_vat_exclusive: {},
                unit_vat_inclusive: {},
                vat: 0
              }
            ],
            product_vat_exclusive: {},
            product_vat_inclusive: {},
            type: '',
            type_description: '',
            type_description_translated: ''
          }
        ],
        id: 0,
        invoice_date: '',
        invoice_number: '',
        request_reference_split_the_bill: [{id: 0, type: ''}],
        status: '',
        total_vat: {},
        total_vat_exclusive: {},
        total_vat_inclusive: {},
        updated: '',
        vat_number: ''
      },
      DraftPayment: {
        entries: [
          {
            alias: {},
            amount: {},
            attachment: [{id: 0, monetary_account_id: 0}],
            counterparty_alias: {},
            description: '',
            id: 0,
            merchant_reference: '',
            type: ''
          }
        ],
        number_of_required_accepts: 0,
        previous_updated_timestamp: '',
        schedule: {
          object: {
            Payment: {
              address_billing: {},
              address_shipping: {},
              alias: {},
              allow_bunqto: false,
              amount: {},
              attachment: [{}],
              balance_after_mutation: {},
              batch_id: 0,
              bunqto_expiry: '',
              bunqto_share_url: '',
              bunqto_status: '',
              bunqto_sub_status: '',
              bunqto_time_responded: '',
              counterparty_alias: {},
              created: '',
              description: '',
              geolocation: {},
              id: 0,
              merchant_reference: '',
              monetary_account_id: 0,
              payment_auto_allocate_instance: {
                created: '',
                error_message: [],
                id: 0,
                payment_auto_allocate_id: 0,
                payment_batch: {payments: {Payment: []}},
                payment_id: 0,
                status: '',
                updated: ''
              },
              request_reference_split_the_bill: [{}],
              scheduled_id: 0,
              sub_type: '',
              type: '',
              updated: ''
            },
            PaymentBatch: {}
          },
          recurrence_size: 0,
          recurrence_unit: '',
          status: '',
          time_end: '',
          time_start: ''
        },
        status: ''
      },
      MasterCardAction: {
        alias: {},
        all_mastercard_action_refund: [
          {
            additional_information: {
              attachment: [{id: 0}],
              category: '',
              comment: '',
              reason: '',
              terms_and_conditions: ''
            },
            alias: {},
            amount: {},
            attachment: [{}],
            category: '',
            comment: '',
            counterparty_alias: {},
            created: '',
            description: '',
            id: 0,
            label_card: {
              expiry_date: '',
              label_user: {},
              second_line: '',
              status: '',
              type: '',
              uuid: ''
            },
            label_user_creator: {},
            mastercard_action_id: 0,
            reason: '',
            reference_mastercard_action_event: [{event_id: 0}],
            status: '',
            status_description: '',
            status_description_translated: '',
            status_together_url: '',
            sub_type: '',
            terms_and_conditions: '',
            time_refund: '',
            type: '',
            updated: ''
          }
        ],
        amount_billing: {},
        amount_converted: {},
        amount_fee: {},
        amount_local: {},
        amount_original_billing: {},
        amount_original_local: {},
        applied_limit: '',
        authorisation_status: '',
        authorisation_type: '',
        card_authorisation_id_response: '',
        card_id: 0,
        city: '',
        clearing_expiry_time: '',
        clearing_status: '',
        counterparty_alias: {},
        decision: '',
        decision_description: '',
        decision_description_translated: '',
        decision_together_url: '',
        description: '',
        eligible_whitelist_id: 0,
        id: 0,
        label_card: {},
        maturity_date: '',
        monetary_account_id: 0,
        pan_entry_mode_user: '',
        payment_status: '',
        pos_card_holder_presence: '',
        pos_card_presence: '',
        request_reference_split_the_bill: [{}],
        reservation_expiry_time: '',
        secure_code_id: 0,
        settlement_status: '',
        token_status: '',
        wallet_provider_id: ''
      },
      Payment: {},
      PaymentBatch: {},
      RequestResponse: {
        address_billing: {},
        address_shipping: {},
        alias: {},
        amount_inquired: {},
        amount_responded: {},
        attachment: [{content_type: '', description: '', urls: [{type: '', url: ''}]}],
        counterparty_alias: {},
        created: '',
        credit_scheme_identifier: '',
        description: '',
        eligible_whitelist_id: 0,
        event_id: 0,
        geolocation: {},
        id: 0,
        mandate_identifier: '',
        minimum_age: 0,
        monetary_account_id: 0,
        redirect_url: '',
        request_reference_split_the_bill: [{}],
        require_address: '',
        status: '',
        sub_type: '',
        time_expiry: '',
        time_refund_requested: '',
        time_refunded: '',
        time_responded: '',
        type: '',
        updated: '',
        user_refund_requested: {}
      },
      ScheduleInstance: {
        error_message: [],
        request_reference_split_the_bill: [{}],
        result_object: {Payment: {}, PaymentBatch: {}},
        scheduled_object: {},
        state: '',
        time_end: '',
        time_start: ''
      },
      TransferwisePayment: {
        alias: {},
        amount_source: {},
        amount_target: {},
        counterparty_alias: {},
        monetary_account_id: '',
        pay_in_reference: '',
        quote: {
          amount_fee: {},
          amount_source: {},
          amount_target: {},
          created: '',
          currency_source: '',
          currency_target: '',
          id: 0,
          quote_id: '',
          rate: '',
          time_delivery_estimate: '',
          time_expiry: '',
          updated: ''
        },
        rate: '',
        recipient_id: '',
        reference: '',
        status: '',
        status_transferwise: '',
        status_transferwise_issue: '',
        sub_status: '',
        time_delivery_estimate: ''
      },
      WhitelistResult: {
        error_message: [],
        id: 0,
        monetary_account_paying_id: 0,
        object: {draftPayment: {}, id: 0, requestResponse: {}},
        request_reference_split_the_bill: [{}],
        status: '',
        sub_status: '',
        whitelist: {}
      }
    },
    require_address: '',
    scheduled_id: 0,
    status: '',
    time_expiry: '',
    time_responded: '',
    updated: '',
    user_alias_created: {},
    user_alias_revoked: {},
    want_tip: false
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"address_billing":{"city":"","country":"","extra":"","house_number":"","is_user_address_updated":false,"mailbox_name":"","po_box":"","postal_code":"","province":"","street":""},"address_shipping":{},"allow_amount_higher":false,"allow_amount_lower":false,"allow_bunqme":false,"amount_inquired":{"currency":"","value":""},"amount_responded":{},"attachment":[{"id":0}],"batch_id":0,"bunqme_share_url":"","counterparty_alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"created":"","description":"","event_id":0,"geolocation":{"altitude":0,"latitude":0,"longitude":0,"radius":0},"id":0,"merchant_reference":"","minimum_age":0,"monetary_account_id":0,"redirect_url":"","reference_split_the_bill":{"BillingInvoice":{"address":{},"alias":{},"category":"","chamber_of_commerce_number":"","counterparty_address":{},"counterparty_alias":{},"created":"","description":"","external_url":"","group":[{"instance_description":"","item":[{"billing_date":"","id":0,"quantity":0,"total_vat_exclusive":{},"total_vat_inclusive":{},"type_description":"","type_description_translated":"","unit_vat_exclusive":{},"unit_vat_inclusive":{},"vat":0}],"product_vat_exclusive":{},"product_vat_inclusive":{},"type":"","type_description":"","type_description_translated":""}],"id":0,"invoice_date":"","invoice_number":"","request_reference_split_the_bill":[{"id":0,"type":""}],"status":"","total_vat":{},"total_vat_exclusive":{},"total_vat_inclusive":{},"updated":"","vat_number":""},"DraftPayment":{"entries":[{"alias":{},"amount":{},"attachment":[{"id":0,"monetary_account_id":0}],"counterparty_alias":{},"description":"","id":0,"merchant_reference":"","type":""}],"number_of_required_accepts":0,"previous_updated_timestamp":"","schedule":{"object":{"Payment":{"address_billing":{},"address_shipping":{},"alias":{},"allow_bunqto":false,"amount":{},"attachment":[{}],"balance_after_mutation":{},"batch_id":0,"bunqto_expiry":"","bunqto_share_url":"","bunqto_status":"","bunqto_sub_status":"","bunqto_time_responded":"","counterparty_alias":{},"created":"","description":"","geolocation":{},"id":0,"merchant_reference":"","monetary_account_id":0,"payment_auto_allocate_instance":{"created":"","error_message":[],"id":0,"payment_auto_allocate_id":0,"payment_batch":{"payments":{"Payment":[]}},"payment_id":0,"status":"","updated":""},"request_reference_split_the_bill":[{}],"scheduled_id":0,"sub_type":"","type":"","updated":""},"PaymentBatch":{}},"recurrence_size":0,"recurrence_unit":"","status":"","time_end":"","time_start":""},"status":""},"MasterCardAction":{"alias":{},"all_mastercard_action_refund":[{"additional_information":{"attachment":[{"id":0}],"category":"","comment":"","reason":"","terms_and_conditions":""},"alias":{},"amount":{},"attachment":[{}],"category":"","comment":"","counterparty_alias":{},"created":"","description":"","id":0,"label_card":{"expiry_date":"","label_user":{},"second_line":"","status":"","type":"","uuid":""},"label_user_creator":{},"mastercard_action_id":0,"reason":"","reference_mastercard_action_event":[{"event_id":0}],"status":"","status_description":"","status_description_translated":"","status_together_url":"","sub_type":"","terms_and_conditions":"","time_refund":"","type":"","updated":""}],"amount_billing":{},"amount_converted":{},"amount_fee":{},"amount_local":{},"amount_original_billing":{},"amount_original_local":{},"applied_limit":"","authorisation_status":"","authorisation_type":"","card_authorisation_id_response":"","card_id":0,"city":"","clearing_expiry_time":"","clearing_status":"","counterparty_alias":{},"decision":"","decision_description":"","decision_description_translated":"","decision_together_url":"","description":"","eligible_whitelist_id":0,"id":0,"label_card":{},"maturity_date":"","monetary_account_id":0,"pan_entry_mode_user":"","payment_status":"","pos_card_holder_presence":"","pos_card_presence":"","request_reference_split_the_bill":[{}],"reservation_expiry_time":"","secure_code_id":0,"settlement_status":"","token_status":"","wallet_provider_id":""},"Payment":{},"PaymentBatch":{},"RequestResponse":{"address_billing":{},"address_shipping":{},"alias":{},"amount_inquired":{},"amount_responded":{},"attachment":[{"content_type":"","description":"","urls":[{"type":"","url":""}]}],"counterparty_alias":{},"created":"","credit_scheme_identifier":"","description":"","eligible_whitelist_id":0,"event_id":0,"geolocation":{},"id":0,"mandate_identifier":"","minimum_age":0,"monetary_account_id":0,"redirect_url":"","request_reference_split_the_bill":[{}],"require_address":"","status":"","sub_type":"","time_expiry":"","time_refund_requested":"","time_refunded":"","time_responded":"","type":"","updated":"","user_refund_requested":{}},"ScheduleInstance":{"error_message":[],"request_reference_split_the_bill":[{}],"result_object":{"Payment":{},"PaymentBatch":{}},"scheduled_object":{},"state":"","time_end":"","time_start":""},"TransferwisePayment":{"alias":{},"amount_source":{},"amount_target":{},"counterparty_alias":{},"monetary_account_id":"","pay_in_reference":"","quote":{"amount_fee":{},"amount_source":{},"amount_target":{},"created":"","currency_source":"","currency_target":"","id":0,"quote_id":"","rate":"","time_delivery_estimate":"","time_expiry":"","updated":""},"rate":"","recipient_id":"","reference":"","status":"","status_transferwise":"","status_transferwise_issue":"","sub_status":"","time_delivery_estimate":""},"WhitelistResult":{"error_message":[],"id":0,"monetary_account_paying_id":0,"object":{"draftPayment":{},"id":0,"requestResponse":{}},"request_reference_split_the_bill":[{}],"status":"","sub_status":"","whitelist":{}}},"require_address":"","scheduled_id":0,"status":"","time_expiry":"","time_responded":"","updated":"","user_alias_created":{},"user_alias_revoked":{},"want_tip":false}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "address_billing": {\n    "city": "",\n    "country": "",\n    "extra": "",\n    "house_number": "",\n    "is_user_address_updated": false,\n    "mailbox_name": "",\n    "po_box": "",\n    "postal_code": "",\n    "province": "",\n    "street": ""\n  },\n  "address_shipping": {},\n  "allow_amount_higher": false,\n  "allow_amount_lower": false,\n  "allow_bunqme": false,\n  "amount_inquired": {\n    "currency": "",\n    "value": ""\n  },\n  "amount_responded": {},\n  "attachment": [\n    {\n      "id": 0\n    }\n  ],\n  "batch_id": 0,\n  "bunqme_share_url": "",\n  "counterparty_alias": {\n    "avatar": {\n      "anchor_uuid": "",\n      "image": [\n        {\n          "attachment_public_uuid": "",\n          "content_type": "",\n          "height": 0,\n          "width": 0\n        }\n      ],\n      "style": "",\n      "uuid": ""\n    },\n    "bunq_me": {\n      "name": "",\n      "service": "",\n      "type": "",\n      "value": ""\n    },\n    "country": "",\n    "display_name": "",\n    "iban": "",\n    "is_light": false,\n    "label_user": {\n      "avatar": {},\n      "country": "",\n      "display_name": "",\n      "public_nick_name": "",\n      "uuid": ""\n    },\n    "merchant_category_code": "",\n    "swift_account_number": "",\n    "swift_bic": "",\n    "transferwise_account_number": "",\n    "transferwise_bank_code": ""\n  },\n  "created": "",\n  "description": "",\n  "event_id": 0,\n  "geolocation": {\n    "altitude": 0,\n    "latitude": 0,\n    "longitude": 0,\n    "radius": 0\n  },\n  "id": 0,\n  "merchant_reference": "",\n  "minimum_age": 0,\n  "monetary_account_id": 0,\n  "redirect_url": "",\n  "reference_split_the_bill": {\n    "BillingInvoice": {\n      "address": {},\n      "alias": {},\n      "category": "",\n      "chamber_of_commerce_number": "",\n      "counterparty_address": {},\n      "counterparty_alias": {},\n      "created": "",\n      "description": "",\n      "external_url": "",\n      "group": [\n        {\n          "instance_description": "",\n          "item": [\n            {\n              "billing_date": "",\n              "id": 0,\n              "quantity": 0,\n              "total_vat_exclusive": {},\n              "total_vat_inclusive": {},\n              "type_description": "",\n              "type_description_translated": "",\n              "unit_vat_exclusive": {},\n              "unit_vat_inclusive": {},\n              "vat": 0\n            }\n          ],\n          "product_vat_exclusive": {},\n          "product_vat_inclusive": {},\n          "type": "",\n          "type_description": "",\n          "type_description_translated": ""\n        }\n      ],\n      "id": 0,\n      "invoice_date": "",\n      "invoice_number": "",\n      "request_reference_split_the_bill": [\n        {\n          "id": 0,\n          "type": ""\n        }\n      ],\n      "status": "",\n      "total_vat": {},\n      "total_vat_exclusive": {},\n      "total_vat_inclusive": {},\n      "updated": "",\n      "vat_number": ""\n    },\n    "DraftPayment": {\n      "entries": [\n        {\n          "alias": {},\n          "amount": {},\n          "attachment": [\n            {\n              "id": 0,\n              "monetary_account_id": 0\n            }\n          ],\n          "counterparty_alias": {},\n          "description": "",\n          "id": 0,\n          "merchant_reference": "",\n          "type": ""\n        }\n      ],\n      "number_of_required_accepts": 0,\n      "previous_updated_timestamp": "",\n      "schedule": {\n        "object": {\n          "Payment": {\n            "address_billing": {},\n            "address_shipping": {},\n            "alias": {},\n            "allow_bunqto": false,\n            "amount": {},\n            "attachment": [\n              {}\n            ],\n            "balance_after_mutation": {},\n            "batch_id": 0,\n            "bunqto_expiry": "",\n            "bunqto_share_url": "",\n            "bunqto_status": "",\n            "bunqto_sub_status": "",\n            "bunqto_time_responded": "",\n            "counterparty_alias": {},\n            "created": "",\n            "description": "",\n            "geolocation": {},\n            "id": 0,\n            "merchant_reference": "",\n            "monetary_account_id": 0,\n            "payment_auto_allocate_instance": {\n              "created": "",\n              "error_message": [],\n              "id": 0,\n              "payment_auto_allocate_id": 0,\n              "payment_batch": {\n                "payments": {\n                  "Payment": []\n                }\n              },\n              "payment_id": 0,\n              "status": "",\n              "updated": ""\n            },\n            "request_reference_split_the_bill": [\n              {}\n            ],\n            "scheduled_id": 0,\n            "sub_type": "",\n            "type": "",\n            "updated": ""\n          },\n          "PaymentBatch": {}\n        },\n        "recurrence_size": 0,\n        "recurrence_unit": "",\n        "status": "",\n        "time_end": "",\n        "time_start": ""\n      },\n      "status": ""\n    },\n    "MasterCardAction": {\n      "alias": {},\n      "all_mastercard_action_refund": [\n        {\n          "additional_information": {\n            "attachment": [\n              {\n                "id": 0\n              }\n            ],\n            "category": "",\n            "comment": "",\n            "reason": "",\n            "terms_and_conditions": ""\n          },\n          "alias": {},\n          "amount": {},\n          "attachment": [\n            {}\n          ],\n          "category": "",\n          "comment": "",\n          "counterparty_alias": {},\n          "created": "",\n          "description": "",\n          "id": 0,\n          "label_card": {\n            "expiry_date": "",\n            "label_user": {},\n            "second_line": "",\n            "status": "",\n            "type": "",\n            "uuid": ""\n          },\n          "label_user_creator": {},\n          "mastercard_action_id": 0,\n          "reason": "",\n          "reference_mastercard_action_event": [\n            {\n              "event_id": 0\n            }\n          ],\n          "status": "",\n          "status_description": "",\n          "status_description_translated": "",\n          "status_together_url": "",\n          "sub_type": "",\n          "terms_and_conditions": "",\n          "time_refund": "",\n          "type": "",\n          "updated": ""\n        }\n      ],\n      "amount_billing": {},\n      "amount_converted": {},\n      "amount_fee": {},\n      "amount_local": {},\n      "amount_original_billing": {},\n      "amount_original_local": {},\n      "applied_limit": "",\n      "authorisation_status": "",\n      "authorisation_type": "",\n      "card_authorisation_id_response": "",\n      "card_id": 0,\n      "city": "",\n      "clearing_expiry_time": "",\n      "clearing_status": "",\n      "counterparty_alias": {},\n      "decision": "",\n      "decision_description": "",\n      "decision_description_translated": "",\n      "decision_together_url": "",\n      "description": "",\n      "eligible_whitelist_id": 0,\n      "id": 0,\n      "label_card": {},\n      "maturity_date": "",\n      "monetary_account_id": 0,\n      "pan_entry_mode_user": "",\n      "payment_status": "",\n      "pos_card_holder_presence": "",\n      "pos_card_presence": "",\n      "request_reference_split_the_bill": [\n        {}\n      ],\n      "reservation_expiry_time": "",\n      "secure_code_id": 0,\n      "settlement_status": "",\n      "token_status": "",\n      "wallet_provider_id": ""\n    },\n    "Payment": {},\n    "PaymentBatch": {},\n    "RequestResponse": {\n      "address_billing": {},\n      "address_shipping": {},\n      "alias": {},\n      "amount_inquired": {},\n      "amount_responded": {},\n      "attachment": [\n        {\n          "content_type": "",\n          "description": "",\n          "urls": [\n            {\n              "type": "",\n              "url": ""\n            }\n          ]\n        }\n      ],\n      "counterparty_alias": {},\n      "created": "",\n      "credit_scheme_identifier": "",\n      "description": "",\n      "eligible_whitelist_id": 0,\n      "event_id": 0,\n      "geolocation": {},\n      "id": 0,\n      "mandate_identifier": "",\n      "minimum_age": 0,\n      "monetary_account_id": 0,\n      "redirect_url": "",\n      "request_reference_split_the_bill": [\n        {}\n      ],\n      "require_address": "",\n      "status": "",\n      "sub_type": "",\n      "time_expiry": "",\n      "time_refund_requested": "",\n      "time_refunded": "",\n      "time_responded": "",\n      "type": "",\n      "updated": "",\n      "user_refund_requested": {}\n    },\n    "ScheduleInstance": {\n      "error_message": [],\n      "request_reference_split_the_bill": [\n        {}\n      ],\n      "result_object": {\n        "Payment": {},\n        "PaymentBatch": {}\n      },\n      "scheduled_object": {},\n      "state": "",\n      "time_end": "",\n      "time_start": ""\n    },\n    "TransferwisePayment": {\n      "alias": {},\n      "amount_source": {},\n      "amount_target": {},\n      "counterparty_alias": {},\n      "monetary_account_id": "",\n      "pay_in_reference": "",\n      "quote": {\n        "amount_fee": {},\n        "amount_source": {},\n        "amount_target": {},\n        "created": "",\n        "currency_source": "",\n        "currency_target": "",\n        "id": 0,\n        "quote_id": "",\n        "rate": "",\n        "time_delivery_estimate": "",\n        "time_expiry": "",\n        "updated": ""\n      },\n      "rate": "",\n      "recipient_id": "",\n      "reference": "",\n      "status": "",\n      "status_transferwise": "",\n      "status_transferwise_issue": "",\n      "sub_status": "",\n      "time_delivery_estimate": ""\n    },\n    "WhitelistResult": {\n      "error_message": [],\n      "id": 0,\n      "monetary_account_paying_id": 0,\n      "object": {\n        "draftPayment": {},\n        "id": 0,\n        "requestResponse": {}\n      },\n      "request_reference_split_the_bill": [\n        {}\n      ],\n      "status": "",\n      "sub_status": "",\n      "whitelist": {}\n    }\n  },\n  "require_address": "",\n  "scheduled_id": 0,\n  "status": "",\n  "time_expiry": "",\n  "time_responded": "",\n  "updated": "",\n  "user_alias_created": {},\n  "user_alias_revoked": {},\n  "want_tip": false\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"allow_amount_higher\": false,\n  \"allow_amount_lower\": false,\n  \"allow_bunqme\": false,\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"id\": 0\n    }\n  ],\n  \"batch_id\": 0,\n  \"bunqme_share_url\": \"\",\n  \"counterparty_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {},\n      \"alias\": {},\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {},\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {},\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"require_address\": \"\",\n  \"scheduled_id\": 0,\n  \"status\": \"\",\n  \"time_expiry\": \"\",\n  \"time_responded\": \"\",\n  \"updated\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {},\n  \"want_tip\": false\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  address_billing: {
    city: '',
    country: '',
    extra: '',
    house_number: '',
    is_user_address_updated: false,
    mailbox_name: '',
    po_box: '',
    postal_code: '',
    province: '',
    street: ''
  },
  address_shipping: {},
  allow_amount_higher: false,
  allow_amount_lower: false,
  allow_bunqme: false,
  amount_inquired: {currency: '', value: ''},
  amount_responded: {},
  attachment: [{id: 0}],
  batch_id: 0,
  bunqme_share_url: '',
  counterparty_alias: {
    avatar: {
      anchor_uuid: '',
      image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
      style: '',
      uuid: ''
    },
    bunq_me: {name: '', service: '', type: '', value: ''},
    country: '',
    display_name: '',
    iban: '',
    is_light: false,
    label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
    merchant_category_code: '',
    swift_account_number: '',
    swift_bic: '',
    transferwise_account_number: '',
    transferwise_bank_code: ''
  },
  created: '',
  description: '',
  event_id: 0,
  geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
  id: 0,
  merchant_reference: '',
  minimum_age: 0,
  monetary_account_id: 0,
  redirect_url: '',
  reference_split_the_bill: {
    BillingInvoice: {
      address: {},
      alias: {},
      category: '',
      chamber_of_commerce_number: '',
      counterparty_address: {},
      counterparty_alias: {},
      created: '',
      description: '',
      external_url: '',
      group: [
        {
          instance_description: '',
          item: [
            {
              billing_date: '',
              id: 0,
              quantity: 0,
              total_vat_exclusive: {},
              total_vat_inclusive: {},
              type_description: '',
              type_description_translated: '',
              unit_vat_exclusive: {},
              unit_vat_inclusive: {},
              vat: 0
            }
          ],
          product_vat_exclusive: {},
          product_vat_inclusive: {},
          type: '',
          type_description: '',
          type_description_translated: ''
        }
      ],
      id: 0,
      invoice_date: '',
      invoice_number: '',
      request_reference_split_the_bill: [{id: 0, type: ''}],
      status: '',
      total_vat: {},
      total_vat_exclusive: {},
      total_vat_inclusive: {},
      updated: '',
      vat_number: ''
    },
    DraftPayment: {
      entries: [
        {
          alias: {},
          amount: {},
          attachment: [{id: 0, monetary_account_id: 0}],
          counterparty_alias: {},
          description: '',
          id: 0,
          merchant_reference: '',
          type: ''
        }
      ],
      number_of_required_accepts: 0,
      previous_updated_timestamp: '',
      schedule: {
        object: {
          Payment: {
            address_billing: {},
            address_shipping: {},
            alias: {},
            allow_bunqto: false,
            amount: {},
            attachment: [{}],
            balance_after_mutation: {},
            batch_id: 0,
            bunqto_expiry: '',
            bunqto_share_url: '',
            bunqto_status: '',
            bunqto_sub_status: '',
            bunqto_time_responded: '',
            counterparty_alias: {},
            created: '',
            description: '',
            geolocation: {},
            id: 0,
            merchant_reference: '',
            monetary_account_id: 0,
            payment_auto_allocate_instance: {
              created: '',
              error_message: [],
              id: 0,
              payment_auto_allocate_id: 0,
              payment_batch: {payments: {Payment: []}},
              payment_id: 0,
              status: '',
              updated: ''
            },
            request_reference_split_the_bill: [{}],
            scheduled_id: 0,
            sub_type: '',
            type: '',
            updated: ''
          },
          PaymentBatch: {}
        },
        recurrence_size: 0,
        recurrence_unit: '',
        status: '',
        time_end: '',
        time_start: ''
      },
      status: ''
    },
    MasterCardAction: {
      alias: {},
      all_mastercard_action_refund: [
        {
          additional_information: {
            attachment: [{id: 0}],
            category: '',
            comment: '',
            reason: '',
            terms_and_conditions: ''
          },
          alias: {},
          amount: {},
          attachment: [{}],
          category: '',
          comment: '',
          counterparty_alias: {},
          created: '',
          description: '',
          id: 0,
          label_card: {
            expiry_date: '',
            label_user: {},
            second_line: '',
            status: '',
            type: '',
            uuid: ''
          },
          label_user_creator: {},
          mastercard_action_id: 0,
          reason: '',
          reference_mastercard_action_event: [{event_id: 0}],
          status: '',
          status_description: '',
          status_description_translated: '',
          status_together_url: '',
          sub_type: '',
          terms_and_conditions: '',
          time_refund: '',
          type: '',
          updated: ''
        }
      ],
      amount_billing: {},
      amount_converted: {},
      amount_fee: {},
      amount_local: {},
      amount_original_billing: {},
      amount_original_local: {},
      applied_limit: '',
      authorisation_status: '',
      authorisation_type: '',
      card_authorisation_id_response: '',
      card_id: 0,
      city: '',
      clearing_expiry_time: '',
      clearing_status: '',
      counterparty_alias: {},
      decision: '',
      decision_description: '',
      decision_description_translated: '',
      decision_together_url: '',
      description: '',
      eligible_whitelist_id: 0,
      id: 0,
      label_card: {},
      maturity_date: '',
      monetary_account_id: 0,
      pan_entry_mode_user: '',
      payment_status: '',
      pos_card_holder_presence: '',
      pos_card_presence: '',
      request_reference_split_the_bill: [{}],
      reservation_expiry_time: '',
      secure_code_id: 0,
      settlement_status: '',
      token_status: '',
      wallet_provider_id: ''
    },
    Payment: {},
    PaymentBatch: {},
    RequestResponse: {
      address_billing: {},
      address_shipping: {},
      alias: {},
      amount_inquired: {},
      amount_responded: {},
      attachment: [{content_type: '', description: '', urls: [{type: '', url: ''}]}],
      counterparty_alias: {},
      created: '',
      credit_scheme_identifier: '',
      description: '',
      eligible_whitelist_id: 0,
      event_id: 0,
      geolocation: {},
      id: 0,
      mandate_identifier: '',
      minimum_age: 0,
      monetary_account_id: 0,
      redirect_url: '',
      request_reference_split_the_bill: [{}],
      require_address: '',
      status: '',
      sub_type: '',
      time_expiry: '',
      time_refund_requested: '',
      time_refunded: '',
      time_responded: '',
      type: '',
      updated: '',
      user_refund_requested: {}
    },
    ScheduleInstance: {
      error_message: [],
      request_reference_split_the_bill: [{}],
      result_object: {Payment: {}, PaymentBatch: {}},
      scheduled_object: {},
      state: '',
      time_end: '',
      time_start: ''
    },
    TransferwisePayment: {
      alias: {},
      amount_source: {},
      amount_target: {},
      counterparty_alias: {},
      monetary_account_id: '',
      pay_in_reference: '',
      quote: {
        amount_fee: {},
        amount_source: {},
        amount_target: {},
        created: '',
        currency_source: '',
        currency_target: '',
        id: 0,
        quote_id: '',
        rate: '',
        time_delivery_estimate: '',
        time_expiry: '',
        updated: ''
      },
      rate: '',
      recipient_id: '',
      reference: '',
      status: '',
      status_transferwise: '',
      status_transferwise_issue: '',
      sub_status: '',
      time_delivery_estimate: ''
    },
    WhitelistResult: {
      error_message: [],
      id: 0,
      monetary_account_paying_id: 0,
      object: {draftPayment: {}, id: 0, requestResponse: {}},
      request_reference_split_the_bill: [{}],
      status: '',
      sub_status: '',
      whitelist: {}
    }
  },
  require_address: '',
  scheduled_id: 0,
  status: '',
  time_expiry: '',
  time_responded: '',
  updated: '',
  user_alias_created: {},
  user_alias_revoked: {},
  want_tip: false
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    address_billing: {
      city: '',
      country: '',
      extra: '',
      house_number: '',
      is_user_address_updated: false,
      mailbox_name: '',
      po_box: '',
      postal_code: '',
      province: '',
      street: ''
    },
    address_shipping: {},
    allow_amount_higher: false,
    allow_amount_lower: false,
    allow_bunqme: false,
    amount_inquired: {currency: '', value: ''},
    amount_responded: {},
    attachment: [{id: 0}],
    batch_id: 0,
    bunqme_share_url: '',
    counterparty_alias: {
      avatar: {
        anchor_uuid: '',
        image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
        style: '',
        uuid: ''
      },
      bunq_me: {name: '', service: '', type: '', value: ''},
      country: '',
      display_name: '',
      iban: '',
      is_light: false,
      label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
      merchant_category_code: '',
      swift_account_number: '',
      swift_bic: '',
      transferwise_account_number: '',
      transferwise_bank_code: ''
    },
    created: '',
    description: '',
    event_id: 0,
    geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
    id: 0,
    merchant_reference: '',
    minimum_age: 0,
    monetary_account_id: 0,
    redirect_url: '',
    reference_split_the_bill: {
      BillingInvoice: {
        address: {},
        alias: {},
        category: '',
        chamber_of_commerce_number: '',
        counterparty_address: {},
        counterparty_alias: {},
        created: '',
        description: '',
        external_url: '',
        group: [
          {
            instance_description: '',
            item: [
              {
                billing_date: '',
                id: 0,
                quantity: 0,
                total_vat_exclusive: {},
                total_vat_inclusive: {},
                type_description: '',
                type_description_translated: '',
                unit_vat_exclusive: {},
                unit_vat_inclusive: {},
                vat: 0
              }
            ],
            product_vat_exclusive: {},
            product_vat_inclusive: {},
            type: '',
            type_description: '',
            type_description_translated: ''
          }
        ],
        id: 0,
        invoice_date: '',
        invoice_number: '',
        request_reference_split_the_bill: [{id: 0, type: ''}],
        status: '',
        total_vat: {},
        total_vat_exclusive: {},
        total_vat_inclusive: {},
        updated: '',
        vat_number: ''
      },
      DraftPayment: {
        entries: [
          {
            alias: {},
            amount: {},
            attachment: [{id: 0, monetary_account_id: 0}],
            counterparty_alias: {},
            description: '',
            id: 0,
            merchant_reference: '',
            type: ''
          }
        ],
        number_of_required_accepts: 0,
        previous_updated_timestamp: '',
        schedule: {
          object: {
            Payment: {
              address_billing: {},
              address_shipping: {},
              alias: {},
              allow_bunqto: false,
              amount: {},
              attachment: [{}],
              balance_after_mutation: {},
              batch_id: 0,
              bunqto_expiry: '',
              bunqto_share_url: '',
              bunqto_status: '',
              bunqto_sub_status: '',
              bunqto_time_responded: '',
              counterparty_alias: {},
              created: '',
              description: '',
              geolocation: {},
              id: 0,
              merchant_reference: '',
              monetary_account_id: 0,
              payment_auto_allocate_instance: {
                created: '',
                error_message: [],
                id: 0,
                payment_auto_allocate_id: 0,
                payment_batch: {payments: {Payment: []}},
                payment_id: 0,
                status: '',
                updated: ''
              },
              request_reference_split_the_bill: [{}],
              scheduled_id: 0,
              sub_type: '',
              type: '',
              updated: ''
            },
            PaymentBatch: {}
          },
          recurrence_size: 0,
          recurrence_unit: '',
          status: '',
          time_end: '',
          time_start: ''
        },
        status: ''
      },
      MasterCardAction: {
        alias: {},
        all_mastercard_action_refund: [
          {
            additional_information: {
              attachment: [{id: 0}],
              category: '',
              comment: '',
              reason: '',
              terms_and_conditions: ''
            },
            alias: {},
            amount: {},
            attachment: [{}],
            category: '',
            comment: '',
            counterparty_alias: {},
            created: '',
            description: '',
            id: 0,
            label_card: {
              expiry_date: '',
              label_user: {},
              second_line: '',
              status: '',
              type: '',
              uuid: ''
            },
            label_user_creator: {},
            mastercard_action_id: 0,
            reason: '',
            reference_mastercard_action_event: [{event_id: 0}],
            status: '',
            status_description: '',
            status_description_translated: '',
            status_together_url: '',
            sub_type: '',
            terms_and_conditions: '',
            time_refund: '',
            type: '',
            updated: ''
          }
        ],
        amount_billing: {},
        amount_converted: {},
        amount_fee: {},
        amount_local: {},
        amount_original_billing: {},
        amount_original_local: {},
        applied_limit: '',
        authorisation_status: '',
        authorisation_type: '',
        card_authorisation_id_response: '',
        card_id: 0,
        city: '',
        clearing_expiry_time: '',
        clearing_status: '',
        counterparty_alias: {},
        decision: '',
        decision_description: '',
        decision_description_translated: '',
        decision_together_url: '',
        description: '',
        eligible_whitelist_id: 0,
        id: 0,
        label_card: {},
        maturity_date: '',
        monetary_account_id: 0,
        pan_entry_mode_user: '',
        payment_status: '',
        pos_card_holder_presence: '',
        pos_card_presence: '',
        request_reference_split_the_bill: [{}],
        reservation_expiry_time: '',
        secure_code_id: 0,
        settlement_status: '',
        token_status: '',
        wallet_provider_id: ''
      },
      Payment: {},
      PaymentBatch: {},
      RequestResponse: {
        address_billing: {},
        address_shipping: {},
        alias: {},
        amount_inquired: {},
        amount_responded: {},
        attachment: [{content_type: '', description: '', urls: [{type: '', url: ''}]}],
        counterparty_alias: {},
        created: '',
        credit_scheme_identifier: '',
        description: '',
        eligible_whitelist_id: 0,
        event_id: 0,
        geolocation: {},
        id: 0,
        mandate_identifier: '',
        minimum_age: 0,
        monetary_account_id: 0,
        redirect_url: '',
        request_reference_split_the_bill: [{}],
        require_address: '',
        status: '',
        sub_type: '',
        time_expiry: '',
        time_refund_requested: '',
        time_refunded: '',
        time_responded: '',
        type: '',
        updated: '',
        user_refund_requested: {}
      },
      ScheduleInstance: {
        error_message: [],
        request_reference_split_the_bill: [{}],
        result_object: {Payment: {}, PaymentBatch: {}},
        scheduled_object: {},
        state: '',
        time_end: '',
        time_start: ''
      },
      TransferwisePayment: {
        alias: {},
        amount_source: {},
        amount_target: {},
        counterparty_alias: {},
        monetary_account_id: '',
        pay_in_reference: '',
        quote: {
          amount_fee: {},
          amount_source: {},
          amount_target: {},
          created: '',
          currency_source: '',
          currency_target: '',
          id: 0,
          quote_id: '',
          rate: '',
          time_delivery_estimate: '',
          time_expiry: '',
          updated: ''
        },
        rate: '',
        recipient_id: '',
        reference: '',
        status: '',
        status_transferwise: '',
        status_transferwise_issue: '',
        sub_status: '',
        time_delivery_estimate: ''
      },
      WhitelistResult: {
        error_message: [],
        id: 0,
        monetary_account_paying_id: 0,
        object: {draftPayment: {}, id: 0, requestResponse: {}},
        request_reference_split_the_bill: [{}],
        status: '',
        sub_status: '',
        whitelist: {}
      }
    },
    require_address: '',
    scheduled_id: 0,
    status: '',
    time_expiry: '',
    time_responded: '',
    updated: '',
    user_alias_created: {},
    user_alias_revoked: {},
    want_tip: false
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  address_billing: {
    city: '',
    country: '',
    extra: '',
    house_number: '',
    is_user_address_updated: false,
    mailbox_name: '',
    po_box: '',
    postal_code: '',
    province: '',
    street: ''
  },
  address_shipping: {},
  allow_amount_higher: false,
  allow_amount_lower: false,
  allow_bunqme: false,
  amount_inquired: {
    currency: '',
    value: ''
  },
  amount_responded: {},
  attachment: [
    {
      id: 0
    }
  ],
  batch_id: 0,
  bunqme_share_url: '',
  counterparty_alias: {
    avatar: {
      anchor_uuid: '',
      image: [
        {
          attachment_public_uuid: '',
          content_type: '',
          height: 0,
          width: 0
        }
      ],
      style: '',
      uuid: ''
    },
    bunq_me: {
      name: '',
      service: '',
      type: '',
      value: ''
    },
    country: '',
    display_name: '',
    iban: '',
    is_light: false,
    label_user: {
      avatar: {},
      country: '',
      display_name: '',
      public_nick_name: '',
      uuid: ''
    },
    merchant_category_code: '',
    swift_account_number: '',
    swift_bic: '',
    transferwise_account_number: '',
    transferwise_bank_code: ''
  },
  created: '',
  description: '',
  event_id: 0,
  geolocation: {
    altitude: 0,
    latitude: 0,
    longitude: 0,
    radius: 0
  },
  id: 0,
  merchant_reference: '',
  minimum_age: 0,
  monetary_account_id: 0,
  redirect_url: '',
  reference_split_the_bill: {
    BillingInvoice: {
      address: {},
      alias: {},
      category: '',
      chamber_of_commerce_number: '',
      counterparty_address: {},
      counterparty_alias: {},
      created: '',
      description: '',
      external_url: '',
      group: [
        {
          instance_description: '',
          item: [
            {
              billing_date: '',
              id: 0,
              quantity: 0,
              total_vat_exclusive: {},
              total_vat_inclusive: {},
              type_description: '',
              type_description_translated: '',
              unit_vat_exclusive: {},
              unit_vat_inclusive: {},
              vat: 0
            }
          ],
          product_vat_exclusive: {},
          product_vat_inclusive: {},
          type: '',
          type_description: '',
          type_description_translated: ''
        }
      ],
      id: 0,
      invoice_date: '',
      invoice_number: '',
      request_reference_split_the_bill: [
        {
          id: 0,
          type: ''
        }
      ],
      status: '',
      total_vat: {},
      total_vat_exclusive: {},
      total_vat_inclusive: {},
      updated: '',
      vat_number: ''
    },
    DraftPayment: {
      entries: [
        {
          alias: {},
          amount: {},
          attachment: [
            {
              id: 0,
              monetary_account_id: 0
            }
          ],
          counterparty_alias: {},
          description: '',
          id: 0,
          merchant_reference: '',
          type: ''
        }
      ],
      number_of_required_accepts: 0,
      previous_updated_timestamp: '',
      schedule: {
        object: {
          Payment: {
            address_billing: {},
            address_shipping: {},
            alias: {},
            allow_bunqto: false,
            amount: {},
            attachment: [
              {}
            ],
            balance_after_mutation: {},
            batch_id: 0,
            bunqto_expiry: '',
            bunqto_share_url: '',
            bunqto_status: '',
            bunqto_sub_status: '',
            bunqto_time_responded: '',
            counterparty_alias: {},
            created: '',
            description: '',
            geolocation: {},
            id: 0,
            merchant_reference: '',
            monetary_account_id: 0,
            payment_auto_allocate_instance: {
              created: '',
              error_message: [],
              id: 0,
              payment_auto_allocate_id: 0,
              payment_batch: {
                payments: {
                  Payment: []
                }
              },
              payment_id: 0,
              status: '',
              updated: ''
            },
            request_reference_split_the_bill: [
              {}
            ],
            scheduled_id: 0,
            sub_type: '',
            type: '',
            updated: ''
          },
          PaymentBatch: {}
        },
        recurrence_size: 0,
        recurrence_unit: '',
        status: '',
        time_end: '',
        time_start: ''
      },
      status: ''
    },
    MasterCardAction: {
      alias: {},
      all_mastercard_action_refund: [
        {
          additional_information: {
            attachment: [
              {
                id: 0
              }
            ],
            category: '',
            comment: '',
            reason: '',
            terms_and_conditions: ''
          },
          alias: {},
          amount: {},
          attachment: [
            {}
          ],
          category: '',
          comment: '',
          counterparty_alias: {},
          created: '',
          description: '',
          id: 0,
          label_card: {
            expiry_date: '',
            label_user: {},
            second_line: '',
            status: '',
            type: '',
            uuid: ''
          },
          label_user_creator: {},
          mastercard_action_id: 0,
          reason: '',
          reference_mastercard_action_event: [
            {
              event_id: 0
            }
          ],
          status: '',
          status_description: '',
          status_description_translated: '',
          status_together_url: '',
          sub_type: '',
          terms_and_conditions: '',
          time_refund: '',
          type: '',
          updated: ''
        }
      ],
      amount_billing: {},
      amount_converted: {},
      amount_fee: {},
      amount_local: {},
      amount_original_billing: {},
      amount_original_local: {},
      applied_limit: '',
      authorisation_status: '',
      authorisation_type: '',
      card_authorisation_id_response: '',
      card_id: 0,
      city: '',
      clearing_expiry_time: '',
      clearing_status: '',
      counterparty_alias: {},
      decision: '',
      decision_description: '',
      decision_description_translated: '',
      decision_together_url: '',
      description: '',
      eligible_whitelist_id: 0,
      id: 0,
      label_card: {},
      maturity_date: '',
      monetary_account_id: 0,
      pan_entry_mode_user: '',
      payment_status: '',
      pos_card_holder_presence: '',
      pos_card_presence: '',
      request_reference_split_the_bill: [
        {}
      ],
      reservation_expiry_time: '',
      secure_code_id: 0,
      settlement_status: '',
      token_status: '',
      wallet_provider_id: ''
    },
    Payment: {},
    PaymentBatch: {},
    RequestResponse: {
      address_billing: {},
      address_shipping: {},
      alias: {},
      amount_inquired: {},
      amount_responded: {},
      attachment: [
        {
          content_type: '',
          description: '',
          urls: [
            {
              type: '',
              url: ''
            }
          ]
        }
      ],
      counterparty_alias: {},
      created: '',
      credit_scheme_identifier: '',
      description: '',
      eligible_whitelist_id: 0,
      event_id: 0,
      geolocation: {},
      id: 0,
      mandate_identifier: '',
      minimum_age: 0,
      monetary_account_id: 0,
      redirect_url: '',
      request_reference_split_the_bill: [
        {}
      ],
      require_address: '',
      status: '',
      sub_type: '',
      time_expiry: '',
      time_refund_requested: '',
      time_refunded: '',
      time_responded: '',
      type: '',
      updated: '',
      user_refund_requested: {}
    },
    ScheduleInstance: {
      error_message: [],
      request_reference_split_the_bill: [
        {}
      ],
      result_object: {
        Payment: {},
        PaymentBatch: {}
      },
      scheduled_object: {},
      state: '',
      time_end: '',
      time_start: ''
    },
    TransferwisePayment: {
      alias: {},
      amount_source: {},
      amount_target: {},
      counterparty_alias: {},
      monetary_account_id: '',
      pay_in_reference: '',
      quote: {
        amount_fee: {},
        amount_source: {},
        amount_target: {},
        created: '',
        currency_source: '',
        currency_target: '',
        id: 0,
        quote_id: '',
        rate: '',
        time_delivery_estimate: '',
        time_expiry: '',
        updated: ''
      },
      rate: '',
      recipient_id: '',
      reference: '',
      status: '',
      status_transferwise: '',
      status_transferwise_issue: '',
      sub_status: '',
      time_delivery_estimate: ''
    },
    WhitelistResult: {
      error_message: [],
      id: 0,
      monetary_account_paying_id: 0,
      object: {
        draftPayment: {},
        id: 0,
        requestResponse: {}
      },
      request_reference_split_the_bill: [
        {}
      ],
      status: '',
      sub_status: '',
      whitelist: {}
    }
  },
  require_address: '',
  scheduled_id: 0,
  status: '',
  time_expiry: '',
  time_responded: '',
  updated: '',
  user_alias_created: {},
  user_alias_revoked: {},
  want_tip: false
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    address_billing: {
      city: '',
      country: '',
      extra: '',
      house_number: '',
      is_user_address_updated: false,
      mailbox_name: '',
      po_box: '',
      postal_code: '',
      province: '',
      street: ''
    },
    address_shipping: {},
    allow_amount_higher: false,
    allow_amount_lower: false,
    allow_bunqme: false,
    amount_inquired: {currency: '', value: ''},
    amount_responded: {},
    attachment: [{id: 0}],
    batch_id: 0,
    bunqme_share_url: '',
    counterparty_alias: {
      avatar: {
        anchor_uuid: '',
        image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
        style: '',
        uuid: ''
      },
      bunq_me: {name: '', service: '', type: '', value: ''},
      country: '',
      display_name: '',
      iban: '',
      is_light: false,
      label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
      merchant_category_code: '',
      swift_account_number: '',
      swift_bic: '',
      transferwise_account_number: '',
      transferwise_bank_code: ''
    },
    created: '',
    description: '',
    event_id: 0,
    geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
    id: 0,
    merchant_reference: '',
    minimum_age: 0,
    monetary_account_id: 0,
    redirect_url: '',
    reference_split_the_bill: {
      BillingInvoice: {
        address: {},
        alias: {},
        category: '',
        chamber_of_commerce_number: '',
        counterparty_address: {},
        counterparty_alias: {},
        created: '',
        description: '',
        external_url: '',
        group: [
          {
            instance_description: '',
            item: [
              {
                billing_date: '',
                id: 0,
                quantity: 0,
                total_vat_exclusive: {},
                total_vat_inclusive: {},
                type_description: '',
                type_description_translated: '',
                unit_vat_exclusive: {},
                unit_vat_inclusive: {},
                vat: 0
              }
            ],
            product_vat_exclusive: {},
            product_vat_inclusive: {},
            type: '',
            type_description: '',
            type_description_translated: ''
          }
        ],
        id: 0,
        invoice_date: '',
        invoice_number: '',
        request_reference_split_the_bill: [{id: 0, type: ''}],
        status: '',
        total_vat: {},
        total_vat_exclusive: {},
        total_vat_inclusive: {},
        updated: '',
        vat_number: ''
      },
      DraftPayment: {
        entries: [
          {
            alias: {},
            amount: {},
            attachment: [{id: 0, monetary_account_id: 0}],
            counterparty_alias: {},
            description: '',
            id: 0,
            merchant_reference: '',
            type: ''
          }
        ],
        number_of_required_accepts: 0,
        previous_updated_timestamp: '',
        schedule: {
          object: {
            Payment: {
              address_billing: {},
              address_shipping: {},
              alias: {},
              allow_bunqto: false,
              amount: {},
              attachment: [{}],
              balance_after_mutation: {},
              batch_id: 0,
              bunqto_expiry: '',
              bunqto_share_url: '',
              bunqto_status: '',
              bunqto_sub_status: '',
              bunqto_time_responded: '',
              counterparty_alias: {},
              created: '',
              description: '',
              geolocation: {},
              id: 0,
              merchant_reference: '',
              monetary_account_id: 0,
              payment_auto_allocate_instance: {
                created: '',
                error_message: [],
                id: 0,
                payment_auto_allocate_id: 0,
                payment_batch: {payments: {Payment: []}},
                payment_id: 0,
                status: '',
                updated: ''
              },
              request_reference_split_the_bill: [{}],
              scheduled_id: 0,
              sub_type: '',
              type: '',
              updated: ''
            },
            PaymentBatch: {}
          },
          recurrence_size: 0,
          recurrence_unit: '',
          status: '',
          time_end: '',
          time_start: ''
        },
        status: ''
      },
      MasterCardAction: {
        alias: {},
        all_mastercard_action_refund: [
          {
            additional_information: {
              attachment: [{id: 0}],
              category: '',
              comment: '',
              reason: '',
              terms_and_conditions: ''
            },
            alias: {},
            amount: {},
            attachment: [{}],
            category: '',
            comment: '',
            counterparty_alias: {},
            created: '',
            description: '',
            id: 0,
            label_card: {
              expiry_date: '',
              label_user: {},
              second_line: '',
              status: '',
              type: '',
              uuid: ''
            },
            label_user_creator: {},
            mastercard_action_id: 0,
            reason: '',
            reference_mastercard_action_event: [{event_id: 0}],
            status: '',
            status_description: '',
            status_description_translated: '',
            status_together_url: '',
            sub_type: '',
            terms_and_conditions: '',
            time_refund: '',
            type: '',
            updated: ''
          }
        ],
        amount_billing: {},
        amount_converted: {},
        amount_fee: {},
        amount_local: {},
        amount_original_billing: {},
        amount_original_local: {},
        applied_limit: '',
        authorisation_status: '',
        authorisation_type: '',
        card_authorisation_id_response: '',
        card_id: 0,
        city: '',
        clearing_expiry_time: '',
        clearing_status: '',
        counterparty_alias: {},
        decision: '',
        decision_description: '',
        decision_description_translated: '',
        decision_together_url: '',
        description: '',
        eligible_whitelist_id: 0,
        id: 0,
        label_card: {},
        maturity_date: '',
        monetary_account_id: 0,
        pan_entry_mode_user: '',
        payment_status: '',
        pos_card_holder_presence: '',
        pos_card_presence: '',
        request_reference_split_the_bill: [{}],
        reservation_expiry_time: '',
        secure_code_id: 0,
        settlement_status: '',
        token_status: '',
        wallet_provider_id: ''
      },
      Payment: {},
      PaymentBatch: {},
      RequestResponse: {
        address_billing: {},
        address_shipping: {},
        alias: {},
        amount_inquired: {},
        amount_responded: {},
        attachment: [{content_type: '', description: '', urls: [{type: '', url: ''}]}],
        counterparty_alias: {},
        created: '',
        credit_scheme_identifier: '',
        description: '',
        eligible_whitelist_id: 0,
        event_id: 0,
        geolocation: {},
        id: 0,
        mandate_identifier: '',
        minimum_age: 0,
        monetary_account_id: 0,
        redirect_url: '',
        request_reference_split_the_bill: [{}],
        require_address: '',
        status: '',
        sub_type: '',
        time_expiry: '',
        time_refund_requested: '',
        time_refunded: '',
        time_responded: '',
        type: '',
        updated: '',
        user_refund_requested: {}
      },
      ScheduleInstance: {
        error_message: [],
        request_reference_split_the_bill: [{}],
        result_object: {Payment: {}, PaymentBatch: {}},
        scheduled_object: {},
        state: '',
        time_end: '',
        time_start: ''
      },
      TransferwisePayment: {
        alias: {},
        amount_source: {},
        amount_target: {},
        counterparty_alias: {},
        monetary_account_id: '',
        pay_in_reference: '',
        quote: {
          amount_fee: {},
          amount_source: {},
          amount_target: {},
          created: '',
          currency_source: '',
          currency_target: '',
          id: 0,
          quote_id: '',
          rate: '',
          time_delivery_estimate: '',
          time_expiry: '',
          updated: ''
        },
        rate: '',
        recipient_id: '',
        reference: '',
        status: '',
        status_transferwise: '',
        status_transferwise_issue: '',
        sub_status: '',
        time_delivery_estimate: ''
      },
      WhitelistResult: {
        error_message: [],
        id: 0,
        monetary_account_paying_id: 0,
        object: {draftPayment: {}, id: 0, requestResponse: {}},
        request_reference_split_the_bill: [{}],
        status: '',
        sub_status: '',
        whitelist: {}
      }
    },
    require_address: '',
    scheduled_id: 0,
    status: '',
    time_expiry: '',
    time_responded: '',
    updated: '',
    user_alias_created: {},
    user_alias_revoked: {},
    want_tip: false
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"address_billing":{"city":"","country":"","extra":"","house_number":"","is_user_address_updated":false,"mailbox_name":"","po_box":"","postal_code":"","province":"","street":""},"address_shipping":{},"allow_amount_higher":false,"allow_amount_lower":false,"allow_bunqme":false,"amount_inquired":{"currency":"","value":""},"amount_responded":{},"attachment":[{"id":0}],"batch_id":0,"bunqme_share_url":"","counterparty_alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"created":"","description":"","event_id":0,"geolocation":{"altitude":0,"latitude":0,"longitude":0,"radius":0},"id":0,"merchant_reference":"","minimum_age":0,"monetary_account_id":0,"redirect_url":"","reference_split_the_bill":{"BillingInvoice":{"address":{},"alias":{},"category":"","chamber_of_commerce_number":"","counterparty_address":{},"counterparty_alias":{},"created":"","description":"","external_url":"","group":[{"instance_description":"","item":[{"billing_date":"","id":0,"quantity":0,"total_vat_exclusive":{},"total_vat_inclusive":{},"type_description":"","type_description_translated":"","unit_vat_exclusive":{},"unit_vat_inclusive":{},"vat":0}],"product_vat_exclusive":{},"product_vat_inclusive":{},"type":"","type_description":"","type_description_translated":""}],"id":0,"invoice_date":"","invoice_number":"","request_reference_split_the_bill":[{"id":0,"type":""}],"status":"","total_vat":{},"total_vat_exclusive":{},"total_vat_inclusive":{},"updated":"","vat_number":""},"DraftPayment":{"entries":[{"alias":{},"amount":{},"attachment":[{"id":0,"monetary_account_id":0}],"counterparty_alias":{},"description":"","id":0,"merchant_reference":"","type":""}],"number_of_required_accepts":0,"previous_updated_timestamp":"","schedule":{"object":{"Payment":{"address_billing":{},"address_shipping":{},"alias":{},"allow_bunqto":false,"amount":{},"attachment":[{}],"balance_after_mutation":{},"batch_id":0,"bunqto_expiry":"","bunqto_share_url":"","bunqto_status":"","bunqto_sub_status":"","bunqto_time_responded":"","counterparty_alias":{},"created":"","description":"","geolocation":{},"id":0,"merchant_reference":"","monetary_account_id":0,"payment_auto_allocate_instance":{"created":"","error_message":[],"id":0,"payment_auto_allocate_id":0,"payment_batch":{"payments":{"Payment":[]}},"payment_id":0,"status":"","updated":""},"request_reference_split_the_bill":[{}],"scheduled_id":0,"sub_type":"","type":"","updated":""},"PaymentBatch":{}},"recurrence_size":0,"recurrence_unit":"","status":"","time_end":"","time_start":""},"status":""},"MasterCardAction":{"alias":{},"all_mastercard_action_refund":[{"additional_information":{"attachment":[{"id":0}],"category":"","comment":"","reason":"","terms_and_conditions":""},"alias":{},"amount":{},"attachment":[{}],"category":"","comment":"","counterparty_alias":{},"created":"","description":"","id":0,"label_card":{"expiry_date":"","label_user":{},"second_line":"","status":"","type":"","uuid":""},"label_user_creator":{},"mastercard_action_id":0,"reason":"","reference_mastercard_action_event":[{"event_id":0}],"status":"","status_description":"","status_description_translated":"","status_together_url":"","sub_type":"","terms_and_conditions":"","time_refund":"","type":"","updated":""}],"amount_billing":{},"amount_converted":{},"amount_fee":{},"amount_local":{},"amount_original_billing":{},"amount_original_local":{},"applied_limit":"","authorisation_status":"","authorisation_type":"","card_authorisation_id_response":"","card_id":0,"city":"","clearing_expiry_time":"","clearing_status":"","counterparty_alias":{},"decision":"","decision_description":"","decision_description_translated":"","decision_together_url":"","description":"","eligible_whitelist_id":0,"id":0,"label_card":{},"maturity_date":"","monetary_account_id":0,"pan_entry_mode_user":"","payment_status":"","pos_card_holder_presence":"","pos_card_presence":"","request_reference_split_the_bill":[{}],"reservation_expiry_time":"","secure_code_id":0,"settlement_status":"","token_status":"","wallet_provider_id":""},"Payment":{},"PaymentBatch":{},"RequestResponse":{"address_billing":{},"address_shipping":{},"alias":{},"amount_inquired":{},"amount_responded":{},"attachment":[{"content_type":"","description":"","urls":[{"type":"","url":""}]}],"counterparty_alias":{},"created":"","credit_scheme_identifier":"","description":"","eligible_whitelist_id":0,"event_id":0,"geolocation":{},"id":0,"mandate_identifier":"","minimum_age":0,"monetary_account_id":0,"redirect_url":"","request_reference_split_the_bill":[{}],"require_address":"","status":"","sub_type":"","time_expiry":"","time_refund_requested":"","time_refunded":"","time_responded":"","type":"","updated":"","user_refund_requested":{}},"ScheduleInstance":{"error_message":[],"request_reference_split_the_bill":[{}],"result_object":{"Payment":{},"PaymentBatch":{}},"scheduled_object":{},"state":"","time_end":"","time_start":""},"TransferwisePayment":{"alias":{},"amount_source":{},"amount_target":{},"counterparty_alias":{},"monetary_account_id":"","pay_in_reference":"","quote":{"amount_fee":{},"amount_source":{},"amount_target":{},"created":"","currency_source":"","currency_target":"","id":0,"quote_id":"","rate":"","time_delivery_estimate":"","time_expiry":"","updated":""},"rate":"","recipient_id":"","reference":"","status":"","status_transferwise":"","status_transferwise_issue":"","sub_status":"","time_delivery_estimate":""},"WhitelistResult":{"error_message":[],"id":0,"monetary_account_paying_id":0,"object":{"draftPayment":{},"id":0,"requestResponse":{}},"request_reference_split_the_bill":[{}],"status":"","sub_status":"","whitelist":{}}},"require_address":"","scheduled_id":0,"status":"","time_expiry":"","time_responded":"","updated":"","user_alias_created":{},"user_alias_revoked":{},"want_tip":false}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"address_billing": @{ @"city": @"", @"country": @"", @"extra": @"", @"house_number": @"", @"is_user_address_updated": @NO, @"mailbox_name": @"", @"po_box": @"", @"postal_code": @"", @"province": @"", @"street": @"" },
                              @"address_shipping": @{  },
                              @"allow_amount_higher": @NO,
                              @"allow_amount_lower": @NO,
                              @"allow_bunqme": @NO,
                              @"amount_inquired": @{ @"currency": @"", @"value": @"" },
                              @"amount_responded": @{  },
                              @"attachment": @[ @{ @"id": @0 } ],
                              @"batch_id": @0,
                              @"bunqme_share_url": @"",
                              @"counterparty_alias": @{ @"avatar": @{ @"anchor_uuid": @"", @"image": @[ @{ @"attachment_public_uuid": @"", @"content_type": @"", @"height": @0, @"width": @0 } ], @"style": @"", @"uuid": @"" }, @"bunq_me": @{ @"name": @"", @"service": @"", @"type": @"", @"value": @"" }, @"country": @"", @"display_name": @"", @"iban": @"", @"is_light": @NO, @"label_user": @{ @"avatar": @{  }, @"country": @"", @"display_name": @"", @"public_nick_name": @"", @"uuid": @"" }, @"merchant_category_code": @"", @"swift_account_number": @"", @"swift_bic": @"", @"transferwise_account_number": @"", @"transferwise_bank_code": @"" },
                              @"created": @"",
                              @"description": @"",
                              @"event_id": @0,
                              @"geolocation": @{ @"altitude": @0, @"latitude": @0, @"longitude": @0, @"radius": @0 },
                              @"id": @0,
                              @"merchant_reference": @"",
                              @"minimum_age": @0,
                              @"monetary_account_id": @0,
                              @"redirect_url": @"",
                              @"reference_split_the_bill": @{ @"BillingInvoice": @{ @"address": @{  }, @"alias": @{  }, @"category": @"", @"chamber_of_commerce_number": @"", @"counterparty_address": @{  }, @"counterparty_alias": @{  }, @"created": @"", @"description": @"", @"external_url": @"", @"group": @[ @{ @"instance_description": @"", @"item": @[ @{ @"billing_date": @"", @"id": @0, @"quantity": @0, @"total_vat_exclusive": @{  }, @"total_vat_inclusive": @{  }, @"type_description": @"", @"type_description_translated": @"", @"unit_vat_exclusive": @{  }, @"unit_vat_inclusive": @{  }, @"vat": @0 } ], @"product_vat_exclusive": @{  }, @"product_vat_inclusive": @{  }, @"type": @"", @"type_description": @"", @"type_description_translated": @"" } ], @"id": @0, @"invoice_date": @"", @"invoice_number": @"", @"request_reference_split_the_bill": @[ @{ @"id": @0, @"type": @"" } ], @"status": @"", @"total_vat": @{  }, @"total_vat_exclusive": @{  }, @"total_vat_inclusive": @{  }, @"updated": @"", @"vat_number": @"" }, @"DraftPayment": @{ @"entries": @[ @{ @"alias": @{  }, @"amount": @{  }, @"attachment": @[ @{ @"id": @0, @"monetary_account_id": @0 } ], @"counterparty_alias": @{  }, @"description": @"", @"id": @0, @"merchant_reference": @"", @"type": @"" } ], @"number_of_required_accepts": @0, @"previous_updated_timestamp": @"", @"schedule": @{ @"object": @{ @"Payment": @{ @"address_billing": @{  }, @"address_shipping": @{  }, @"alias": @{  }, @"allow_bunqto": @NO, @"amount": @{  }, @"attachment": @[ @{  } ], @"balance_after_mutation": @{  }, @"batch_id": @0, @"bunqto_expiry": @"", @"bunqto_share_url": @"", @"bunqto_status": @"", @"bunqto_sub_status": @"", @"bunqto_time_responded": @"", @"counterparty_alias": @{  }, @"created": @"", @"description": @"", @"geolocation": @{  }, @"id": @0, @"merchant_reference": @"", @"monetary_account_id": @0, @"payment_auto_allocate_instance": @{ @"created": @"", @"error_message": @[  ], @"id": @0, @"payment_auto_allocate_id": @0, @"payment_batch": @{ @"payments": @{ @"Payment": @[  ] } }, @"payment_id": @0, @"status": @"", @"updated": @"" }, @"request_reference_split_the_bill": @[ @{  } ], @"scheduled_id": @0, @"sub_type": @"", @"type": @"", @"updated": @"" }, @"PaymentBatch": @{  } }, @"recurrence_size": @0, @"recurrence_unit": @"", @"status": @"", @"time_end": @"", @"time_start": @"" }, @"status": @"" }, @"MasterCardAction": @{ @"alias": @{  }, @"all_mastercard_action_refund": @[ @{ @"additional_information": @{ @"attachment": @[ @{ @"id": @0 } ], @"category": @"", @"comment": @"", @"reason": @"", @"terms_and_conditions": @"" }, @"alias": @{  }, @"amount": @{  }, @"attachment": @[ @{  } ], @"category": @"", @"comment": @"", @"counterparty_alias": @{  }, @"created": @"", @"description": @"", @"id": @0, @"label_card": @{ @"expiry_date": @"", @"label_user": @{  }, @"second_line": @"", @"status": @"", @"type": @"", @"uuid": @"" }, @"label_user_creator": @{  }, @"mastercard_action_id": @0, @"reason": @"", @"reference_mastercard_action_event": @[ @{ @"event_id": @0 } ], @"status": @"", @"status_description": @"", @"status_description_translated": @"", @"status_together_url": @"", @"sub_type": @"", @"terms_and_conditions": @"", @"time_refund": @"", @"type": @"", @"updated": @"" } ], @"amount_billing": @{  }, @"amount_converted": @{  }, @"amount_fee": @{  }, @"amount_local": @{  }, @"amount_original_billing": @{  }, @"amount_original_local": @{  }, @"applied_limit": @"", @"authorisation_status": @"", @"authorisation_type": @"", @"card_authorisation_id_response": @"", @"card_id": @0, @"city": @"", @"clearing_expiry_time": @"", @"clearing_status": @"", @"counterparty_alias": @{  }, @"decision": @"", @"decision_description": @"", @"decision_description_translated": @"", @"decision_together_url": @"", @"description": @"", @"eligible_whitelist_id": @0, @"id": @0, @"label_card": @{  }, @"maturity_date": @"", @"monetary_account_id": @0, @"pan_entry_mode_user": @"", @"payment_status": @"", @"pos_card_holder_presence": @"", @"pos_card_presence": @"", @"request_reference_split_the_bill": @[ @{  } ], @"reservation_expiry_time": @"", @"secure_code_id": @0, @"settlement_status": @"", @"token_status": @"", @"wallet_provider_id": @"" }, @"Payment": @{  }, @"PaymentBatch": @{  }, @"RequestResponse": @{ @"address_billing": @{  }, @"address_shipping": @{  }, @"alias": @{  }, @"amount_inquired": @{  }, @"amount_responded": @{  }, @"attachment": @[ @{ @"content_type": @"", @"description": @"", @"urls": @[ @{ @"type": @"", @"url": @"" } ] } ], @"counterparty_alias": @{  }, @"created": @"", @"credit_scheme_identifier": @"", @"description": @"", @"eligible_whitelist_id": @0, @"event_id": @0, @"geolocation": @{  }, @"id": @0, @"mandate_identifier": @"", @"minimum_age": @0, @"monetary_account_id": @0, @"redirect_url": @"", @"request_reference_split_the_bill": @[ @{  } ], @"require_address": @"", @"status": @"", @"sub_type": @"", @"time_expiry": @"", @"time_refund_requested": @"", @"time_refunded": @"", @"time_responded": @"", @"type": @"", @"updated": @"", @"user_refund_requested": @{  } }, @"ScheduleInstance": @{ @"error_message": @[  ], @"request_reference_split_the_bill": @[ @{  } ], @"result_object": @{ @"Payment": @{  }, @"PaymentBatch": @{  } }, @"scheduled_object": @{  }, @"state": @"", @"time_end": @"", @"time_start": @"" }, @"TransferwisePayment": @{ @"alias": @{  }, @"amount_source": @{  }, @"amount_target": @{  }, @"counterparty_alias": @{  }, @"monetary_account_id": @"", @"pay_in_reference": @"", @"quote": @{ @"amount_fee": @{  }, @"amount_source": @{  }, @"amount_target": @{  }, @"created": @"", @"currency_source": @"", @"currency_target": @"", @"id": @0, @"quote_id": @"", @"rate": @"", @"time_delivery_estimate": @"", @"time_expiry": @"", @"updated": @"" }, @"rate": @"", @"recipient_id": @"", @"reference": @"", @"status": @"", @"status_transferwise": @"", @"status_transferwise_issue": @"", @"sub_status": @"", @"time_delivery_estimate": @"" }, @"WhitelistResult": @{ @"error_message": @[  ], @"id": @0, @"monetary_account_paying_id": @0, @"object": @{ @"draftPayment": @{  }, @"id": @0, @"requestResponse": @{  } }, @"request_reference_split_the_bill": @[ @{  } ], @"status": @"", @"sub_status": @"", @"whitelist": @{  } } },
                              @"require_address": @"",
                              @"scheduled_id": @0,
                              @"status": @"",
                              @"time_expiry": @"",
                              @"time_responded": @"",
                              @"updated": @"",
                              @"user_alias_created": @{  },
                              @"user_alias_revoked": @{  },
                              @"want_tip": @NO };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"allow_amount_higher\": false,\n  \"allow_amount_lower\": false,\n  \"allow_bunqme\": false,\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"id\": 0\n    }\n  ],\n  \"batch_id\": 0,\n  \"bunqme_share_url\": \"\",\n  \"counterparty_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {},\n      \"alias\": {},\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {},\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {},\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"require_address\": \"\",\n  \"scheduled_id\": 0,\n  \"status\": \"\",\n  \"time_expiry\": \"\",\n  \"time_responded\": \"\",\n  \"updated\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {},\n  \"want_tip\": false\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'address_billing' => [
        'city' => '',
        'country' => '',
        'extra' => '',
        'house_number' => '',
        'is_user_address_updated' => null,
        'mailbox_name' => '',
        'po_box' => '',
        'postal_code' => '',
        'province' => '',
        'street' => ''
    ],
    'address_shipping' => [
        
    ],
    'allow_amount_higher' => null,
    'allow_amount_lower' => null,
    'allow_bunqme' => null,
    'amount_inquired' => [
        'currency' => '',
        'value' => ''
    ],
    'amount_responded' => [
        
    ],
    'attachment' => [
        [
                'id' => 0
        ]
    ],
    'batch_id' => 0,
    'bunqme_share_url' => '',
    'counterparty_alias' => [
        'avatar' => [
                'anchor_uuid' => '',
                'image' => [
                                [
                                                                'attachment_public_uuid' => '',
                                                                'content_type' => '',
                                                                'height' => 0,
                                                                'width' => 0
                                ]
                ],
                'style' => '',
                'uuid' => ''
        ],
        'bunq_me' => [
                'name' => '',
                'service' => '',
                'type' => '',
                'value' => ''
        ],
        'country' => '',
        'display_name' => '',
        'iban' => '',
        'is_light' => null,
        'label_user' => [
                'avatar' => [
                                
                ],
                'country' => '',
                'display_name' => '',
                'public_nick_name' => '',
                'uuid' => ''
        ],
        'merchant_category_code' => '',
        'swift_account_number' => '',
        'swift_bic' => '',
        'transferwise_account_number' => '',
        'transferwise_bank_code' => ''
    ],
    'created' => '',
    'description' => '',
    'event_id' => 0,
    'geolocation' => [
        'altitude' => 0,
        'latitude' => 0,
        'longitude' => 0,
        'radius' => 0
    ],
    'id' => 0,
    'merchant_reference' => '',
    'minimum_age' => 0,
    'monetary_account_id' => 0,
    'redirect_url' => '',
    'reference_split_the_bill' => [
        'BillingInvoice' => [
                'address' => [
                                
                ],
                'alias' => [
                                
                ],
                'category' => '',
                'chamber_of_commerce_number' => '',
                'counterparty_address' => [
                                
                ],
                'counterparty_alias' => [
                                
                ],
                'created' => '',
                'description' => '',
                'external_url' => '',
                'group' => [
                                [
                                                                'instance_description' => '',
                                                                'item' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'billing_date' => '',
                                                                                                                                                                                                                                                                'id' => 0,
                                                                                                                                                                                                                                                                'quantity' => 0,
                                                                                                                                                                                                                                                                'total_vat_exclusive' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'total_vat_inclusive' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'type_description' => '',
                                                                                                                                                                                                                                                                'type_description_translated' => '',
                                                                                                                                                                                                                                                                'unit_vat_exclusive' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'unit_vat_inclusive' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'vat' => 0
                                                                                                                                ]
                                                                ],
                                                                'product_vat_exclusive' => [
                                                                                                                                
                                                                ],
                                                                'product_vat_inclusive' => [
                                                                                                                                
                                                                ],
                                                                'type' => '',
                                                                'type_description' => '',
                                                                'type_description_translated' => ''
                                ]
                ],
                'id' => 0,
                'invoice_date' => '',
                'invoice_number' => '',
                'request_reference_split_the_bill' => [
                                [
                                                                'id' => 0,
                                                                'type' => ''
                                ]
                ],
                'status' => '',
                'total_vat' => [
                                
                ],
                'total_vat_exclusive' => [
                                
                ],
                'total_vat_inclusive' => [
                                
                ],
                'updated' => '',
                'vat_number' => ''
        ],
        'DraftPayment' => [
                'entries' => [
                                [
                                                                'alias' => [
                                                                                                                                
                                                                ],
                                                                'amount' => [
                                                                                                                                
                                                                ],
                                                                'attachment' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'id' => 0,
                                                                                                                                                                                                                                                                'monetary_account_id' => 0
                                                                                                                                ]
                                                                ],
                                                                'counterparty_alias' => [
                                                                                                                                
                                                                ],
                                                                'description' => '',
                                                                'id' => 0,
                                                                'merchant_reference' => '',
                                                                'type' => ''
                                ]
                ],
                'number_of_required_accepts' => 0,
                'previous_updated_timestamp' => '',
                'schedule' => [
                                'object' => [
                                                                'Payment' => [
                                                                                                                                'address_billing' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'address_shipping' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'alias' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'allow_bunqto' => null,
                                                                                                                                'amount' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'attachment' => [
                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'balance_after_mutation' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'batch_id' => 0,
                                                                                                                                'bunqto_expiry' => '',
                                                                                                                                'bunqto_share_url' => '',
                                                                                                                                'bunqto_status' => '',
                                                                                                                                'bunqto_sub_status' => '',
                                                                                                                                'bunqto_time_responded' => '',
                                                                                                                                'counterparty_alias' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'created' => '',
                                                                                                                                'description' => '',
                                                                                                                                'geolocation' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'id' => 0,
                                                                                                                                'merchant_reference' => '',
                                                                                                                                'monetary_account_id' => 0,
                                                                                                                                'payment_auto_allocate_instance' => [
                                                                                                                                                                                                                                                                'created' => '',
                                                                                                                                                                                                                                                                'error_message' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'id' => 0,
                                                                                                                                                                                                                                                                'payment_auto_allocate_id' => 0,
                                                                                                                                                                                                                                                                'payment_batch' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'payments' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'Payment' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'payment_id' => 0,
                                                                                                                                                                                                                                                                'status' => '',
                                                                                                                                                                                                                                                                'updated' => ''
                                                                                                                                ],
                                                                                                                                'request_reference_split_the_bill' => [
                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'scheduled_id' => 0,
                                                                                                                                'sub_type' => '',
                                                                                                                                'type' => '',
                                                                                                                                'updated' => ''
                                                                ],
                                                                'PaymentBatch' => [
                                                                                                                                
                                                                ]
                                ],
                                'recurrence_size' => 0,
                                'recurrence_unit' => '',
                                'status' => '',
                                'time_end' => '',
                                'time_start' => ''
                ],
                'status' => ''
        ],
        'MasterCardAction' => [
                'alias' => [
                                
                ],
                'all_mastercard_action_refund' => [
                                [
                                                                'additional_information' => [
                                                                                                                                'attachment' => [
                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'id' => 0
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'category' => '',
                                                                                                                                'comment' => '',
                                                                                                                                'reason' => '',
                                                                                                                                'terms_and_conditions' => ''
                                                                ],
                                                                'alias' => [
                                                                                                                                
                                                                ],
                                                                'amount' => [
                                                                                                                                
                                                                ],
                                                                'attachment' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'category' => '',
                                                                'comment' => '',
                                                                'counterparty_alias' => [
                                                                                                                                
                                                                ],
                                                                'created' => '',
                                                                'description' => '',
                                                                'id' => 0,
                                                                'label_card' => [
                                                                                                                                'expiry_date' => '',
                                                                                                                                'label_user' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'second_line' => '',
                                                                                                                                'status' => '',
                                                                                                                                'type' => '',
                                                                                                                                'uuid' => ''
                                                                ],
                                                                'label_user_creator' => [
                                                                                                                                
                                                                ],
                                                                'mastercard_action_id' => 0,
                                                                'reason' => '',
                                                                'reference_mastercard_action_event' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'event_id' => 0
                                                                                                                                ]
                                                                ],
                                                                'status' => '',
                                                                'status_description' => '',
                                                                'status_description_translated' => '',
                                                                'status_together_url' => '',
                                                                'sub_type' => '',
                                                                'terms_and_conditions' => '',
                                                                'time_refund' => '',
                                                                'type' => '',
                                                                'updated' => ''
                                ]
                ],
                'amount_billing' => [
                                
                ],
                'amount_converted' => [
                                
                ],
                'amount_fee' => [
                                
                ],
                'amount_local' => [
                                
                ],
                'amount_original_billing' => [
                                
                ],
                'amount_original_local' => [
                                
                ],
                'applied_limit' => '',
                'authorisation_status' => '',
                'authorisation_type' => '',
                'card_authorisation_id_response' => '',
                'card_id' => 0,
                'city' => '',
                'clearing_expiry_time' => '',
                'clearing_status' => '',
                'counterparty_alias' => [
                                
                ],
                'decision' => '',
                'decision_description' => '',
                'decision_description_translated' => '',
                'decision_together_url' => '',
                'description' => '',
                'eligible_whitelist_id' => 0,
                'id' => 0,
                'label_card' => [
                                
                ],
                'maturity_date' => '',
                'monetary_account_id' => 0,
                'pan_entry_mode_user' => '',
                'payment_status' => '',
                'pos_card_holder_presence' => '',
                'pos_card_presence' => '',
                'request_reference_split_the_bill' => [
                                [
                                                                
                                ]
                ],
                'reservation_expiry_time' => '',
                'secure_code_id' => 0,
                'settlement_status' => '',
                'token_status' => '',
                'wallet_provider_id' => ''
        ],
        'Payment' => [
                
        ],
        'PaymentBatch' => [
                
        ],
        'RequestResponse' => [
                'address_billing' => [
                                
                ],
                'address_shipping' => [
                                
                ],
                'alias' => [
                                
                ],
                'amount_inquired' => [
                                
                ],
                'amount_responded' => [
                                
                ],
                'attachment' => [
                                [
                                                                'content_type' => '',
                                                                'description' => '',
                                                                'urls' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'type' => '',
                                                                                                                                                                                                                                                                'url' => ''
                                                                                                                                ]
                                                                ]
                                ]
                ],
                'counterparty_alias' => [
                                
                ],
                'created' => '',
                'credit_scheme_identifier' => '',
                'description' => '',
                'eligible_whitelist_id' => 0,
                'event_id' => 0,
                'geolocation' => [
                                
                ],
                'id' => 0,
                'mandate_identifier' => '',
                'minimum_age' => 0,
                'monetary_account_id' => 0,
                'redirect_url' => '',
                'request_reference_split_the_bill' => [
                                [
                                                                
                                ]
                ],
                'require_address' => '',
                'status' => '',
                'sub_type' => '',
                'time_expiry' => '',
                'time_refund_requested' => '',
                'time_refunded' => '',
                'time_responded' => '',
                'type' => '',
                'updated' => '',
                'user_refund_requested' => [
                                
                ]
        ],
        'ScheduleInstance' => [
                'error_message' => [
                                
                ],
                'request_reference_split_the_bill' => [
                                [
                                                                
                                ]
                ],
                'result_object' => [
                                'Payment' => [
                                                                
                                ],
                                'PaymentBatch' => [
                                                                
                                ]
                ],
                'scheduled_object' => [
                                
                ],
                'state' => '',
                'time_end' => '',
                'time_start' => ''
        ],
        'TransferwisePayment' => [
                'alias' => [
                                
                ],
                'amount_source' => [
                                
                ],
                'amount_target' => [
                                
                ],
                'counterparty_alias' => [
                                
                ],
                'monetary_account_id' => '',
                'pay_in_reference' => '',
                'quote' => [
                                'amount_fee' => [
                                                                
                                ],
                                'amount_source' => [
                                                                
                                ],
                                'amount_target' => [
                                                                
                                ],
                                'created' => '',
                                'currency_source' => '',
                                'currency_target' => '',
                                'id' => 0,
                                'quote_id' => '',
                                'rate' => '',
                                'time_delivery_estimate' => '',
                                'time_expiry' => '',
                                'updated' => ''
                ],
                'rate' => '',
                'recipient_id' => '',
                'reference' => '',
                'status' => '',
                'status_transferwise' => '',
                'status_transferwise_issue' => '',
                'sub_status' => '',
                'time_delivery_estimate' => ''
        ],
        'WhitelistResult' => [
                'error_message' => [
                                
                ],
                'id' => 0,
                'monetary_account_paying_id' => 0,
                'object' => [
                                'draftPayment' => [
                                                                
                                ],
                                'id' => 0,
                                'requestResponse' => [
                                                                
                                ]
                ],
                'request_reference_split_the_bill' => [
                                [
                                                                
                                ]
                ],
                'status' => '',
                'sub_status' => '',
                'whitelist' => [
                                
                ]
        ]
    ],
    'require_address' => '',
    'scheduled_id' => 0,
    'status' => '',
    'time_expiry' => '',
    'time_responded' => '',
    'updated' => '',
    'user_alias_created' => [
        
    ],
    'user_alias_revoked' => [
        
    ],
    'want_tip' => null
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry', [
  'body' => '{
  "address_billing": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_shipping": {},
  "allow_amount_higher": false,
  "allow_amount_lower": false,
  "allow_bunqme": false,
  "amount_inquired": {
    "currency": "",
    "value": ""
  },
  "amount_responded": {},
  "attachment": [
    {
      "id": 0
    }
  ],
  "batch_id": 0,
  "bunqme_share_url": "",
  "counterparty_alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "created": "",
  "description": "",
  "event_id": 0,
  "geolocation": {
    "altitude": 0,
    "latitude": 0,
    "longitude": 0,
    "radius": 0
  },
  "id": 0,
  "merchant_reference": "",
  "minimum_age": 0,
  "monetary_account_id": 0,
  "redirect_url": "",
  "reference_split_the_bill": {
    "BillingInvoice": {
      "address": {},
      "alias": {},
      "category": "",
      "chamber_of_commerce_number": "",
      "counterparty_address": {},
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "external_url": "",
      "group": [
        {
          "instance_description": "",
          "item": [
            {
              "billing_date": "",
              "id": 0,
              "quantity": 0,
              "total_vat_exclusive": {},
              "total_vat_inclusive": {},
              "type_description": "",
              "type_description_translated": "",
              "unit_vat_exclusive": {},
              "unit_vat_inclusive": {},
              "vat": 0
            }
          ],
          "product_vat_exclusive": {},
          "product_vat_inclusive": {},
          "type": "",
          "type_description": "",
          "type_description_translated": ""
        }
      ],
      "id": 0,
      "invoice_date": "",
      "invoice_number": "",
      "request_reference_split_the_bill": [
        {
          "id": 0,
          "type": ""
        }
      ],
      "status": "",
      "total_vat": {},
      "total_vat_exclusive": {},
      "total_vat_inclusive": {},
      "updated": "",
      "vat_number": ""
    },
    "DraftPayment": {
      "entries": [
        {
          "alias": {},
          "amount": {},
          "attachment": [
            {
              "id": 0,
              "monetary_account_id": 0
            }
          ],
          "counterparty_alias": {},
          "description": "",
          "id": 0,
          "merchant_reference": "",
          "type": ""
        }
      ],
      "number_of_required_accepts": 0,
      "previous_updated_timestamp": "",
      "schedule": {
        "object": {
          "Payment": {
            "address_billing": {},
            "address_shipping": {},
            "alias": {},
            "allow_bunqto": false,
            "amount": {},
            "attachment": [
              {}
            ],
            "balance_after_mutation": {},
            "batch_id": 0,
            "bunqto_expiry": "",
            "bunqto_share_url": "",
            "bunqto_status": "",
            "bunqto_sub_status": "",
            "bunqto_time_responded": "",
            "counterparty_alias": {},
            "created": "",
            "description": "",
            "geolocation": {},
            "id": 0,
            "merchant_reference": "",
            "monetary_account_id": 0,
            "payment_auto_allocate_instance": {
              "created": "",
              "error_message": [],
              "id": 0,
              "payment_auto_allocate_id": 0,
              "payment_batch": {
                "payments": {
                  "Payment": []
                }
              },
              "payment_id": 0,
              "status": "",
              "updated": ""
            },
            "request_reference_split_the_bill": [
              {}
            ],
            "scheduled_id": 0,
            "sub_type": "",
            "type": "",
            "updated": ""
          },
          "PaymentBatch": {}
        },
        "recurrence_size": 0,
        "recurrence_unit": "",
        "status": "",
        "time_end": "",
        "time_start": ""
      },
      "status": ""
    },
    "MasterCardAction": {
      "alias": {},
      "all_mastercard_action_refund": [
        {
          "additional_information": {
            "attachment": [
              {
                "id": 0
              }
            ],
            "category": "",
            "comment": "",
            "reason": "",
            "terms_and_conditions": ""
          },
          "alias": {},
          "amount": {},
          "attachment": [
            {}
          ],
          "category": "",
          "comment": "",
          "counterparty_alias": {},
          "created": "",
          "description": "",
          "id": 0,
          "label_card": {
            "expiry_date": "",
            "label_user": {},
            "second_line": "",
            "status": "",
            "type": "",
            "uuid": ""
          },
          "label_user_creator": {},
          "mastercard_action_id": 0,
          "reason": "",
          "reference_mastercard_action_event": [
            {
              "event_id": 0
            }
          ],
          "status": "",
          "status_description": "",
          "status_description_translated": "",
          "status_together_url": "",
          "sub_type": "",
          "terms_and_conditions": "",
          "time_refund": "",
          "type": "",
          "updated": ""
        }
      ],
      "amount_billing": {},
      "amount_converted": {},
      "amount_fee": {},
      "amount_local": {},
      "amount_original_billing": {},
      "amount_original_local": {},
      "applied_limit": "",
      "authorisation_status": "",
      "authorisation_type": "",
      "card_authorisation_id_response": "",
      "card_id": 0,
      "city": "",
      "clearing_expiry_time": "",
      "clearing_status": "",
      "counterparty_alias": {},
      "decision": "",
      "decision_description": "",
      "decision_description_translated": "",
      "decision_together_url": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "id": 0,
      "label_card": {},
      "maturity_date": "",
      "monetary_account_id": 0,
      "pan_entry_mode_user": "",
      "payment_status": "",
      "pos_card_holder_presence": "",
      "pos_card_presence": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "reservation_expiry_time": "",
      "secure_code_id": 0,
      "settlement_status": "",
      "token_status": "",
      "wallet_provider_id": ""
    },
    "Payment": {},
    "PaymentBatch": {},
    "RequestResponse": {
      "address_billing": {},
      "address_shipping": {},
      "alias": {},
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "content_type": "",
          "description": "",
          "urls": [
            {
              "type": "",
              "url": ""
            }
          ]
        }
      ],
      "counterparty_alias": {},
      "created": "",
      "credit_scheme_identifier": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "mandate_identifier": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "require_address": "",
      "status": "",
      "sub_type": "",
      "time_expiry": "",
      "time_refund_requested": "",
      "time_refunded": "",
      "time_responded": "",
      "type": "",
      "updated": "",
      "user_refund_requested": {}
    },
    "ScheduleInstance": {
      "error_message": [],
      "request_reference_split_the_bill": [
        {}
      ],
      "result_object": {
        "Payment": {},
        "PaymentBatch": {}
      },
      "scheduled_object": {},
      "state": "",
      "time_end": "",
      "time_start": ""
    },
    "TransferwisePayment": {
      "alias": {},
      "amount_source": {},
      "amount_target": {},
      "counterparty_alias": {},
      "monetary_account_id": "",
      "pay_in_reference": "",
      "quote": {
        "amount_fee": {},
        "amount_source": {},
        "amount_target": {},
        "created": "",
        "currency_source": "",
        "currency_target": "",
        "id": 0,
        "quote_id": "",
        "rate": "",
        "time_delivery_estimate": "",
        "time_expiry": "",
        "updated": ""
      },
      "rate": "",
      "recipient_id": "",
      "reference": "",
      "status": "",
      "status_transferwise": "",
      "status_transferwise_issue": "",
      "sub_status": "",
      "time_delivery_estimate": ""
    },
    "WhitelistResult": {
      "error_message": [],
      "id": 0,
      "monetary_account_paying_id": 0,
      "object": {
        "draftPayment": {},
        "id": 0,
        "requestResponse": {}
      },
      "request_reference_split_the_bill": [
        {}
      ],
      "status": "",
      "sub_status": "",
      "whitelist": {}
    }
  },
  "require_address": "",
  "scheduled_id": 0,
  "status": "",
  "time_expiry": "",
  "time_responded": "",
  "updated": "",
  "user_alias_created": {},
  "user_alias_revoked": {},
  "want_tip": false
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'address_billing' => [
    'city' => '',
    'country' => '',
    'extra' => '',
    'house_number' => '',
    'is_user_address_updated' => null,
    'mailbox_name' => '',
    'po_box' => '',
    'postal_code' => '',
    'province' => '',
    'street' => ''
  ],
  'address_shipping' => [
    
  ],
  'allow_amount_higher' => null,
  'allow_amount_lower' => null,
  'allow_bunqme' => null,
  'amount_inquired' => [
    'currency' => '',
    'value' => ''
  ],
  'amount_responded' => [
    
  ],
  'attachment' => [
    [
        'id' => 0
    ]
  ],
  'batch_id' => 0,
  'bunqme_share_url' => '',
  'counterparty_alias' => [
    'avatar' => [
        'anchor_uuid' => '',
        'image' => [
                [
                                'attachment_public_uuid' => '',
                                'content_type' => '',
                                'height' => 0,
                                'width' => 0
                ]
        ],
        'style' => '',
        'uuid' => ''
    ],
    'bunq_me' => [
        'name' => '',
        'service' => '',
        'type' => '',
        'value' => ''
    ],
    'country' => '',
    'display_name' => '',
    'iban' => '',
    'is_light' => null,
    'label_user' => [
        'avatar' => [
                
        ],
        'country' => '',
        'display_name' => '',
        'public_nick_name' => '',
        'uuid' => ''
    ],
    'merchant_category_code' => '',
    'swift_account_number' => '',
    'swift_bic' => '',
    'transferwise_account_number' => '',
    'transferwise_bank_code' => ''
  ],
  'created' => '',
  'description' => '',
  'event_id' => 0,
  'geolocation' => [
    'altitude' => 0,
    'latitude' => 0,
    'longitude' => 0,
    'radius' => 0
  ],
  'id' => 0,
  'merchant_reference' => '',
  'minimum_age' => 0,
  'monetary_account_id' => 0,
  'redirect_url' => '',
  'reference_split_the_bill' => [
    'BillingInvoice' => [
        'address' => [
                
        ],
        'alias' => [
                
        ],
        'category' => '',
        'chamber_of_commerce_number' => '',
        'counterparty_address' => [
                
        ],
        'counterparty_alias' => [
                
        ],
        'created' => '',
        'description' => '',
        'external_url' => '',
        'group' => [
                [
                                'instance_description' => '',
                                'item' => [
                                                                [
                                                                                                                                'billing_date' => '',
                                                                                                                                'id' => 0,
                                                                                                                                'quantity' => 0,
                                                                                                                                'total_vat_exclusive' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'total_vat_inclusive' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'type_description' => '',
                                                                                                                                'type_description_translated' => '',
                                                                                                                                'unit_vat_exclusive' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'unit_vat_inclusive' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'vat' => 0
                                                                ]
                                ],
                                'product_vat_exclusive' => [
                                                                
                                ],
                                'product_vat_inclusive' => [
                                                                
                                ],
                                'type' => '',
                                'type_description' => '',
                                'type_description_translated' => ''
                ]
        ],
        'id' => 0,
        'invoice_date' => '',
        'invoice_number' => '',
        'request_reference_split_the_bill' => [
                [
                                'id' => 0,
                                'type' => ''
                ]
        ],
        'status' => '',
        'total_vat' => [
                
        ],
        'total_vat_exclusive' => [
                
        ],
        'total_vat_inclusive' => [
                
        ],
        'updated' => '',
        'vat_number' => ''
    ],
    'DraftPayment' => [
        'entries' => [
                [
                                'alias' => [
                                                                
                                ],
                                'amount' => [
                                                                
                                ],
                                'attachment' => [
                                                                [
                                                                                                                                'id' => 0,
                                                                                                                                'monetary_account_id' => 0
                                                                ]
                                ],
                                'counterparty_alias' => [
                                                                
                                ],
                                'description' => '',
                                'id' => 0,
                                'merchant_reference' => '',
                                'type' => ''
                ]
        ],
        'number_of_required_accepts' => 0,
        'previous_updated_timestamp' => '',
        'schedule' => [
                'object' => [
                                'Payment' => [
                                                                'address_billing' => [
                                                                                                                                
                                                                ],
                                                                'address_shipping' => [
                                                                                                                                
                                                                ],
                                                                'alias' => [
                                                                                                                                
                                                                ],
                                                                'allow_bunqto' => null,
                                                                'amount' => [
                                                                                                                                
                                                                ],
                                                                'attachment' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'balance_after_mutation' => [
                                                                                                                                
                                                                ],
                                                                'batch_id' => 0,
                                                                'bunqto_expiry' => '',
                                                                'bunqto_share_url' => '',
                                                                'bunqto_status' => '',
                                                                'bunqto_sub_status' => '',
                                                                'bunqto_time_responded' => '',
                                                                'counterparty_alias' => [
                                                                                                                                
                                                                ],
                                                                'created' => '',
                                                                'description' => '',
                                                                'geolocation' => [
                                                                                                                                
                                                                ],
                                                                'id' => 0,
                                                                'merchant_reference' => '',
                                                                'monetary_account_id' => 0,
                                                                'payment_auto_allocate_instance' => [
                                                                                                                                'created' => '',
                                                                                                                                'error_message' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'id' => 0,
                                                                                                                                'payment_auto_allocate_id' => 0,
                                                                                                                                'payment_batch' => [
                                                                                                                                                                                                                                                                'payments' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'Payment' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'payment_id' => 0,
                                                                                                                                'status' => '',
                                                                                                                                'updated' => ''
                                                                ],
                                                                'request_reference_split_the_bill' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'scheduled_id' => 0,
                                                                'sub_type' => '',
                                                                'type' => '',
                                                                'updated' => ''
                                ],
                                'PaymentBatch' => [
                                                                
                                ]
                ],
                'recurrence_size' => 0,
                'recurrence_unit' => '',
                'status' => '',
                'time_end' => '',
                'time_start' => ''
        ],
        'status' => ''
    ],
    'MasterCardAction' => [
        'alias' => [
                
        ],
        'all_mastercard_action_refund' => [
                [
                                'additional_information' => [
                                                                'attachment' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'id' => 0
                                                                                                                                ]
                                                                ],
                                                                'category' => '',
                                                                'comment' => '',
                                                                'reason' => '',
                                                                'terms_and_conditions' => ''
                                ],
                                'alias' => [
                                                                
                                ],
                                'amount' => [
                                                                
                                ],
                                'attachment' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'category' => '',
                                'comment' => '',
                                'counterparty_alias' => [
                                                                
                                ],
                                'created' => '',
                                'description' => '',
                                'id' => 0,
                                'label_card' => [
                                                                'expiry_date' => '',
                                                                'label_user' => [
                                                                                                                                
                                                                ],
                                                                'second_line' => '',
                                                                'status' => '',
                                                                'type' => '',
                                                                'uuid' => ''
                                ],
                                'label_user_creator' => [
                                                                
                                ],
                                'mastercard_action_id' => 0,
                                'reason' => '',
                                'reference_mastercard_action_event' => [
                                                                [
                                                                                                                                'event_id' => 0
                                                                ]
                                ],
                                'status' => '',
                                'status_description' => '',
                                'status_description_translated' => '',
                                'status_together_url' => '',
                                'sub_type' => '',
                                'terms_and_conditions' => '',
                                'time_refund' => '',
                                'type' => '',
                                'updated' => ''
                ]
        ],
        'amount_billing' => [
                
        ],
        'amount_converted' => [
                
        ],
        'amount_fee' => [
                
        ],
        'amount_local' => [
                
        ],
        'amount_original_billing' => [
                
        ],
        'amount_original_local' => [
                
        ],
        'applied_limit' => '',
        'authorisation_status' => '',
        'authorisation_type' => '',
        'card_authorisation_id_response' => '',
        'card_id' => 0,
        'city' => '',
        'clearing_expiry_time' => '',
        'clearing_status' => '',
        'counterparty_alias' => [
                
        ],
        'decision' => '',
        'decision_description' => '',
        'decision_description_translated' => '',
        'decision_together_url' => '',
        'description' => '',
        'eligible_whitelist_id' => 0,
        'id' => 0,
        'label_card' => [
                
        ],
        'maturity_date' => '',
        'monetary_account_id' => 0,
        'pan_entry_mode_user' => '',
        'payment_status' => '',
        'pos_card_holder_presence' => '',
        'pos_card_presence' => '',
        'request_reference_split_the_bill' => [
                [
                                
                ]
        ],
        'reservation_expiry_time' => '',
        'secure_code_id' => 0,
        'settlement_status' => '',
        'token_status' => '',
        'wallet_provider_id' => ''
    ],
    'Payment' => [
        
    ],
    'PaymentBatch' => [
        
    ],
    'RequestResponse' => [
        'address_billing' => [
                
        ],
        'address_shipping' => [
                
        ],
        'alias' => [
                
        ],
        'amount_inquired' => [
                
        ],
        'amount_responded' => [
                
        ],
        'attachment' => [
                [
                                'content_type' => '',
                                'description' => '',
                                'urls' => [
                                                                [
                                                                                                                                'type' => '',
                                                                                                                                'url' => ''
                                                                ]
                                ]
                ]
        ],
        'counterparty_alias' => [
                
        ],
        'created' => '',
        'credit_scheme_identifier' => '',
        'description' => '',
        'eligible_whitelist_id' => 0,
        'event_id' => 0,
        'geolocation' => [
                
        ],
        'id' => 0,
        'mandate_identifier' => '',
        'minimum_age' => 0,
        'monetary_account_id' => 0,
        'redirect_url' => '',
        'request_reference_split_the_bill' => [
                [
                                
                ]
        ],
        'require_address' => '',
        'status' => '',
        'sub_type' => '',
        'time_expiry' => '',
        'time_refund_requested' => '',
        'time_refunded' => '',
        'time_responded' => '',
        'type' => '',
        'updated' => '',
        'user_refund_requested' => [
                
        ]
    ],
    'ScheduleInstance' => [
        'error_message' => [
                
        ],
        'request_reference_split_the_bill' => [
                [
                                
                ]
        ],
        'result_object' => [
                'Payment' => [
                                
                ],
                'PaymentBatch' => [
                                
                ]
        ],
        'scheduled_object' => [
                
        ],
        'state' => '',
        'time_end' => '',
        'time_start' => ''
    ],
    'TransferwisePayment' => [
        'alias' => [
                
        ],
        'amount_source' => [
                
        ],
        'amount_target' => [
                
        ],
        'counterparty_alias' => [
                
        ],
        'monetary_account_id' => '',
        'pay_in_reference' => '',
        'quote' => [
                'amount_fee' => [
                                
                ],
                'amount_source' => [
                                
                ],
                'amount_target' => [
                                
                ],
                'created' => '',
                'currency_source' => '',
                'currency_target' => '',
                'id' => 0,
                'quote_id' => '',
                'rate' => '',
                'time_delivery_estimate' => '',
                'time_expiry' => '',
                'updated' => ''
        ],
        'rate' => '',
        'recipient_id' => '',
        'reference' => '',
        'status' => '',
        'status_transferwise' => '',
        'status_transferwise_issue' => '',
        'sub_status' => '',
        'time_delivery_estimate' => ''
    ],
    'WhitelistResult' => [
        'error_message' => [
                
        ],
        'id' => 0,
        'monetary_account_paying_id' => 0,
        'object' => [
                'draftPayment' => [
                                
                ],
                'id' => 0,
                'requestResponse' => [
                                
                ]
        ],
        'request_reference_split_the_bill' => [
                [
                                
                ]
        ],
        'status' => '',
        'sub_status' => '',
        'whitelist' => [
                
        ]
    ]
  ],
  'require_address' => '',
  'scheduled_id' => 0,
  'status' => '',
  'time_expiry' => '',
  'time_responded' => '',
  'updated' => '',
  'user_alias_created' => [
    
  ],
  'user_alias_revoked' => [
    
  ],
  'want_tip' => null
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'address_billing' => [
    'city' => '',
    'country' => '',
    'extra' => '',
    'house_number' => '',
    'is_user_address_updated' => null,
    'mailbox_name' => '',
    'po_box' => '',
    'postal_code' => '',
    'province' => '',
    'street' => ''
  ],
  'address_shipping' => [
    
  ],
  'allow_amount_higher' => null,
  'allow_amount_lower' => null,
  'allow_bunqme' => null,
  'amount_inquired' => [
    'currency' => '',
    'value' => ''
  ],
  'amount_responded' => [
    
  ],
  'attachment' => [
    [
        'id' => 0
    ]
  ],
  'batch_id' => 0,
  'bunqme_share_url' => '',
  'counterparty_alias' => [
    'avatar' => [
        'anchor_uuid' => '',
        'image' => [
                [
                                'attachment_public_uuid' => '',
                                'content_type' => '',
                                'height' => 0,
                                'width' => 0
                ]
        ],
        'style' => '',
        'uuid' => ''
    ],
    'bunq_me' => [
        'name' => '',
        'service' => '',
        'type' => '',
        'value' => ''
    ],
    'country' => '',
    'display_name' => '',
    'iban' => '',
    'is_light' => null,
    'label_user' => [
        'avatar' => [
                
        ],
        'country' => '',
        'display_name' => '',
        'public_nick_name' => '',
        'uuid' => ''
    ],
    'merchant_category_code' => '',
    'swift_account_number' => '',
    'swift_bic' => '',
    'transferwise_account_number' => '',
    'transferwise_bank_code' => ''
  ],
  'created' => '',
  'description' => '',
  'event_id' => 0,
  'geolocation' => [
    'altitude' => 0,
    'latitude' => 0,
    'longitude' => 0,
    'radius' => 0
  ],
  'id' => 0,
  'merchant_reference' => '',
  'minimum_age' => 0,
  'monetary_account_id' => 0,
  'redirect_url' => '',
  'reference_split_the_bill' => [
    'BillingInvoice' => [
        'address' => [
                
        ],
        'alias' => [
                
        ],
        'category' => '',
        'chamber_of_commerce_number' => '',
        'counterparty_address' => [
                
        ],
        'counterparty_alias' => [
                
        ],
        'created' => '',
        'description' => '',
        'external_url' => '',
        'group' => [
                [
                                'instance_description' => '',
                                'item' => [
                                                                [
                                                                                                                                'billing_date' => '',
                                                                                                                                'id' => 0,
                                                                                                                                'quantity' => 0,
                                                                                                                                'total_vat_exclusive' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'total_vat_inclusive' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'type_description' => '',
                                                                                                                                'type_description_translated' => '',
                                                                                                                                'unit_vat_exclusive' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'unit_vat_inclusive' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'vat' => 0
                                                                ]
                                ],
                                'product_vat_exclusive' => [
                                                                
                                ],
                                'product_vat_inclusive' => [
                                                                
                                ],
                                'type' => '',
                                'type_description' => '',
                                'type_description_translated' => ''
                ]
        ],
        'id' => 0,
        'invoice_date' => '',
        'invoice_number' => '',
        'request_reference_split_the_bill' => [
                [
                                'id' => 0,
                                'type' => ''
                ]
        ],
        'status' => '',
        'total_vat' => [
                
        ],
        'total_vat_exclusive' => [
                
        ],
        'total_vat_inclusive' => [
                
        ],
        'updated' => '',
        'vat_number' => ''
    ],
    'DraftPayment' => [
        'entries' => [
                [
                                'alias' => [
                                                                
                                ],
                                'amount' => [
                                                                
                                ],
                                'attachment' => [
                                                                [
                                                                                                                                'id' => 0,
                                                                                                                                'monetary_account_id' => 0
                                                                ]
                                ],
                                'counterparty_alias' => [
                                                                
                                ],
                                'description' => '',
                                'id' => 0,
                                'merchant_reference' => '',
                                'type' => ''
                ]
        ],
        'number_of_required_accepts' => 0,
        'previous_updated_timestamp' => '',
        'schedule' => [
                'object' => [
                                'Payment' => [
                                                                'address_billing' => [
                                                                                                                                
                                                                ],
                                                                'address_shipping' => [
                                                                                                                                
                                                                ],
                                                                'alias' => [
                                                                                                                                
                                                                ],
                                                                'allow_bunqto' => null,
                                                                'amount' => [
                                                                                                                                
                                                                ],
                                                                'attachment' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'balance_after_mutation' => [
                                                                                                                                
                                                                ],
                                                                'batch_id' => 0,
                                                                'bunqto_expiry' => '',
                                                                'bunqto_share_url' => '',
                                                                'bunqto_status' => '',
                                                                'bunqto_sub_status' => '',
                                                                'bunqto_time_responded' => '',
                                                                'counterparty_alias' => [
                                                                                                                                
                                                                ],
                                                                'created' => '',
                                                                'description' => '',
                                                                'geolocation' => [
                                                                                                                                
                                                                ],
                                                                'id' => 0,
                                                                'merchant_reference' => '',
                                                                'monetary_account_id' => 0,
                                                                'payment_auto_allocate_instance' => [
                                                                                                                                'created' => '',
                                                                                                                                'error_message' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'id' => 0,
                                                                                                                                'payment_auto_allocate_id' => 0,
                                                                                                                                'payment_batch' => [
                                                                                                                                                                                                                                                                'payments' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'Payment' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'payment_id' => 0,
                                                                                                                                'status' => '',
                                                                                                                                'updated' => ''
                                                                ],
                                                                'request_reference_split_the_bill' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'scheduled_id' => 0,
                                                                'sub_type' => '',
                                                                'type' => '',
                                                                'updated' => ''
                                ],
                                'PaymentBatch' => [
                                                                
                                ]
                ],
                'recurrence_size' => 0,
                'recurrence_unit' => '',
                'status' => '',
                'time_end' => '',
                'time_start' => ''
        ],
        'status' => ''
    ],
    'MasterCardAction' => [
        'alias' => [
                
        ],
        'all_mastercard_action_refund' => [
                [
                                'additional_information' => [
                                                                'attachment' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'id' => 0
                                                                                                                                ]
                                                                ],
                                                                'category' => '',
                                                                'comment' => '',
                                                                'reason' => '',
                                                                'terms_and_conditions' => ''
                                ],
                                'alias' => [
                                                                
                                ],
                                'amount' => [
                                                                
                                ],
                                'attachment' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'category' => '',
                                'comment' => '',
                                'counterparty_alias' => [
                                                                
                                ],
                                'created' => '',
                                'description' => '',
                                'id' => 0,
                                'label_card' => [
                                                                'expiry_date' => '',
                                                                'label_user' => [
                                                                                                                                
                                                                ],
                                                                'second_line' => '',
                                                                'status' => '',
                                                                'type' => '',
                                                                'uuid' => ''
                                ],
                                'label_user_creator' => [
                                                                
                                ],
                                'mastercard_action_id' => 0,
                                'reason' => '',
                                'reference_mastercard_action_event' => [
                                                                [
                                                                                                                                'event_id' => 0
                                                                ]
                                ],
                                'status' => '',
                                'status_description' => '',
                                'status_description_translated' => '',
                                'status_together_url' => '',
                                'sub_type' => '',
                                'terms_and_conditions' => '',
                                'time_refund' => '',
                                'type' => '',
                                'updated' => ''
                ]
        ],
        'amount_billing' => [
                
        ],
        'amount_converted' => [
                
        ],
        'amount_fee' => [
                
        ],
        'amount_local' => [
                
        ],
        'amount_original_billing' => [
                
        ],
        'amount_original_local' => [
                
        ],
        'applied_limit' => '',
        'authorisation_status' => '',
        'authorisation_type' => '',
        'card_authorisation_id_response' => '',
        'card_id' => 0,
        'city' => '',
        'clearing_expiry_time' => '',
        'clearing_status' => '',
        'counterparty_alias' => [
                
        ],
        'decision' => '',
        'decision_description' => '',
        'decision_description_translated' => '',
        'decision_together_url' => '',
        'description' => '',
        'eligible_whitelist_id' => 0,
        'id' => 0,
        'label_card' => [
                
        ],
        'maturity_date' => '',
        'monetary_account_id' => 0,
        'pan_entry_mode_user' => '',
        'payment_status' => '',
        'pos_card_holder_presence' => '',
        'pos_card_presence' => '',
        'request_reference_split_the_bill' => [
                [
                                
                ]
        ],
        'reservation_expiry_time' => '',
        'secure_code_id' => 0,
        'settlement_status' => '',
        'token_status' => '',
        'wallet_provider_id' => ''
    ],
    'Payment' => [
        
    ],
    'PaymentBatch' => [
        
    ],
    'RequestResponse' => [
        'address_billing' => [
                
        ],
        'address_shipping' => [
                
        ],
        'alias' => [
                
        ],
        'amount_inquired' => [
                
        ],
        'amount_responded' => [
                
        ],
        'attachment' => [
                [
                                'content_type' => '',
                                'description' => '',
                                'urls' => [
                                                                [
                                                                                                                                'type' => '',
                                                                                                                                'url' => ''
                                                                ]
                                ]
                ]
        ],
        'counterparty_alias' => [
                
        ],
        'created' => '',
        'credit_scheme_identifier' => '',
        'description' => '',
        'eligible_whitelist_id' => 0,
        'event_id' => 0,
        'geolocation' => [
                
        ],
        'id' => 0,
        'mandate_identifier' => '',
        'minimum_age' => 0,
        'monetary_account_id' => 0,
        'redirect_url' => '',
        'request_reference_split_the_bill' => [
                [
                                
                ]
        ],
        'require_address' => '',
        'status' => '',
        'sub_type' => '',
        'time_expiry' => '',
        'time_refund_requested' => '',
        'time_refunded' => '',
        'time_responded' => '',
        'type' => '',
        'updated' => '',
        'user_refund_requested' => [
                
        ]
    ],
    'ScheduleInstance' => [
        'error_message' => [
                
        ],
        'request_reference_split_the_bill' => [
                [
                                
                ]
        ],
        'result_object' => [
                'Payment' => [
                                
                ],
                'PaymentBatch' => [
                                
                ]
        ],
        'scheduled_object' => [
                
        ],
        'state' => '',
        'time_end' => '',
        'time_start' => ''
    ],
    'TransferwisePayment' => [
        'alias' => [
                
        ],
        'amount_source' => [
                
        ],
        'amount_target' => [
                
        ],
        'counterparty_alias' => [
                
        ],
        'monetary_account_id' => '',
        'pay_in_reference' => '',
        'quote' => [
                'amount_fee' => [
                                
                ],
                'amount_source' => [
                                
                ],
                'amount_target' => [
                                
                ],
                'created' => '',
                'currency_source' => '',
                'currency_target' => '',
                'id' => 0,
                'quote_id' => '',
                'rate' => '',
                'time_delivery_estimate' => '',
                'time_expiry' => '',
                'updated' => ''
        ],
        'rate' => '',
        'recipient_id' => '',
        'reference' => '',
        'status' => '',
        'status_transferwise' => '',
        'status_transferwise_issue' => '',
        'sub_status' => '',
        'time_delivery_estimate' => ''
    ],
    'WhitelistResult' => [
        'error_message' => [
                
        ],
        'id' => 0,
        'monetary_account_paying_id' => 0,
        'object' => [
                'draftPayment' => [
                                
                ],
                'id' => 0,
                'requestResponse' => [
                                
                ]
        ],
        'request_reference_split_the_bill' => [
                [
                                
                ]
        ],
        'status' => '',
        'sub_status' => '',
        'whitelist' => [
                
        ]
    ]
  ],
  'require_address' => '',
  'scheduled_id' => 0,
  'status' => '',
  'time_expiry' => '',
  'time_responded' => '',
  'updated' => '',
  'user_alias_created' => [
    
  ],
  'user_alias_revoked' => [
    
  ],
  'want_tip' => null
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "address_billing": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_shipping": {},
  "allow_amount_higher": false,
  "allow_amount_lower": false,
  "allow_bunqme": false,
  "amount_inquired": {
    "currency": "",
    "value": ""
  },
  "amount_responded": {},
  "attachment": [
    {
      "id": 0
    }
  ],
  "batch_id": 0,
  "bunqme_share_url": "",
  "counterparty_alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "created": "",
  "description": "",
  "event_id": 0,
  "geolocation": {
    "altitude": 0,
    "latitude": 0,
    "longitude": 0,
    "radius": 0
  },
  "id": 0,
  "merchant_reference": "",
  "minimum_age": 0,
  "monetary_account_id": 0,
  "redirect_url": "",
  "reference_split_the_bill": {
    "BillingInvoice": {
      "address": {},
      "alias": {},
      "category": "",
      "chamber_of_commerce_number": "",
      "counterparty_address": {},
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "external_url": "",
      "group": [
        {
          "instance_description": "",
          "item": [
            {
              "billing_date": "",
              "id": 0,
              "quantity": 0,
              "total_vat_exclusive": {},
              "total_vat_inclusive": {},
              "type_description": "",
              "type_description_translated": "",
              "unit_vat_exclusive": {},
              "unit_vat_inclusive": {},
              "vat": 0
            }
          ],
          "product_vat_exclusive": {},
          "product_vat_inclusive": {},
          "type": "",
          "type_description": "",
          "type_description_translated": ""
        }
      ],
      "id": 0,
      "invoice_date": "",
      "invoice_number": "",
      "request_reference_split_the_bill": [
        {
          "id": 0,
          "type": ""
        }
      ],
      "status": "",
      "total_vat": {},
      "total_vat_exclusive": {},
      "total_vat_inclusive": {},
      "updated": "",
      "vat_number": ""
    },
    "DraftPayment": {
      "entries": [
        {
          "alias": {},
          "amount": {},
          "attachment": [
            {
              "id": 0,
              "monetary_account_id": 0
            }
          ],
          "counterparty_alias": {},
          "description": "",
          "id": 0,
          "merchant_reference": "",
          "type": ""
        }
      ],
      "number_of_required_accepts": 0,
      "previous_updated_timestamp": "",
      "schedule": {
        "object": {
          "Payment": {
            "address_billing": {},
            "address_shipping": {},
            "alias": {},
            "allow_bunqto": false,
            "amount": {},
            "attachment": [
              {}
            ],
            "balance_after_mutation": {},
            "batch_id": 0,
            "bunqto_expiry": "",
            "bunqto_share_url": "",
            "bunqto_status": "",
            "bunqto_sub_status": "",
            "bunqto_time_responded": "",
            "counterparty_alias": {},
            "created": "",
            "description": "",
            "geolocation": {},
            "id": 0,
            "merchant_reference": "",
            "monetary_account_id": 0,
            "payment_auto_allocate_instance": {
              "created": "",
              "error_message": [],
              "id": 0,
              "payment_auto_allocate_id": 0,
              "payment_batch": {
                "payments": {
                  "Payment": []
                }
              },
              "payment_id": 0,
              "status": "",
              "updated": ""
            },
            "request_reference_split_the_bill": [
              {}
            ],
            "scheduled_id": 0,
            "sub_type": "",
            "type": "",
            "updated": ""
          },
          "PaymentBatch": {}
        },
        "recurrence_size": 0,
        "recurrence_unit": "",
        "status": "",
        "time_end": "",
        "time_start": ""
      },
      "status": ""
    },
    "MasterCardAction": {
      "alias": {},
      "all_mastercard_action_refund": [
        {
          "additional_information": {
            "attachment": [
              {
                "id": 0
              }
            ],
            "category": "",
            "comment": "",
            "reason": "",
            "terms_and_conditions": ""
          },
          "alias": {},
          "amount": {},
          "attachment": [
            {}
          ],
          "category": "",
          "comment": "",
          "counterparty_alias": {},
          "created": "",
          "description": "",
          "id": 0,
          "label_card": {
            "expiry_date": "",
            "label_user": {},
            "second_line": "",
            "status": "",
            "type": "",
            "uuid": ""
          },
          "label_user_creator": {},
          "mastercard_action_id": 0,
          "reason": "",
          "reference_mastercard_action_event": [
            {
              "event_id": 0
            }
          ],
          "status": "",
          "status_description": "",
          "status_description_translated": "",
          "status_together_url": "",
          "sub_type": "",
          "terms_and_conditions": "",
          "time_refund": "",
          "type": "",
          "updated": ""
        }
      ],
      "amount_billing": {},
      "amount_converted": {},
      "amount_fee": {},
      "amount_local": {},
      "amount_original_billing": {},
      "amount_original_local": {},
      "applied_limit": "",
      "authorisation_status": "",
      "authorisation_type": "",
      "card_authorisation_id_response": "",
      "card_id": 0,
      "city": "",
      "clearing_expiry_time": "",
      "clearing_status": "",
      "counterparty_alias": {},
      "decision": "",
      "decision_description": "",
      "decision_description_translated": "",
      "decision_together_url": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "id": 0,
      "label_card": {},
      "maturity_date": "",
      "monetary_account_id": 0,
      "pan_entry_mode_user": "",
      "payment_status": "",
      "pos_card_holder_presence": "",
      "pos_card_presence": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "reservation_expiry_time": "",
      "secure_code_id": 0,
      "settlement_status": "",
      "token_status": "",
      "wallet_provider_id": ""
    },
    "Payment": {},
    "PaymentBatch": {},
    "RequestResponse": {
      "address_billing": {},
      "address_shipping": {},
      "alias": {},
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "content_type": "",
          "description": "",
          "urls": [
            {
              "type": "",
              "url": ""
            }
          ]
        }
      ],
      "counterparty_alias": {},
      "created": "",
      "credit_scheme_identifier": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "mandate_identifier": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "require_address": "",
      "status": "",
      "sub_type": "",
      "time_expiry": "",
      "time_refund_requested": "",
      "time_refunded": "",
      "time_responded": "",
      "type": "",
      "updated": "",
      "user_refund_requested": {}
    },
    "ScheduleInstance": {
      "error_message": [],
      "request_reference_split_the_bill": [
        {}
      ],
      "result_object": {
        "Payment": {},
        "PaymentBatch": {}
      },
      "scheduled_object": {},
      "state": "",
      "time_end": "",
      "time_start": ""
    },
    "TransferwisePayment": {
      "alias": {},
      "amount_source": {},
      "amount_target": {},
      "counterparty_alias": {},
      "monetary_account_id": "",
      "pay_in_reference": "",
      "quote": {
        "amount_fee": {},
        "amount_source": {},
        "amount_target": {},
        "created": "",
        "currency_source": "",
        "currency_target": "",
        "id": 0,
        "quote_id": "",
        "rate": "",
        "time_delivery_estimate": "",
        "time_expiry": "",
        "updated": ""
      },
      "rate": "",
      "recipient_id": "",
      "reference": "",
      "status": "",
      "status_transferwise": "",
      "status_transferwise_issue": "",
      "sub_status": "",
      "time_delivery_estimate": ""
    },
    "WhitelistResult": {
      "error_message": [],
      "id": 0,
      "monetary_account_paying_id": 0,
      "object": {
        "draftPayment": {},
        "id": 0,
        "requestResponse": {}
      },
      "request_reference_split_the_bill": [
        {}
      ],
      "status": "",
      "sub_status": "",
      "whitelist": {}
    }
  },
  "require_address": "",
  "scheduled_id": 0,
  "status": "",
  "time_expiry": "",
  "time_responded": "",
  "updated": "",
  "user_alias_created": {},
  "user_alias_revoked": {},
  "want_tip": false
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "address_billing": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_shipping": {},
  "allow_amount_higher": false,
  "allow_amount_lower": false,
  "allow_bunqme": false,
  "amount_inquired": {
    "currency": "",
    "value": ""
  },
  "amount_responded": {},
  "attachment": [
    {
      "id": 0
    }
  ],
  "batch_id": 0,
  "bunqme_share_url": "",
  "counterparty_alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "created": "",
  "description": "",
  "event_id": 0,
  "geolocation": {
    "altitude": 0,
    "latitude": 0,
    "longitude": 0,
    "radius": 0
  },
  "id": 0,
  "merchant_reference": "",
  "minimum_age": 0,
  "monetary_account_id": 0,
  "redirect_url": "",
  "reference_split_the_bill": {
    "BillingInvoice": {
      "address": {},
      "alias": {},
      "category": "",
      "chamber_of_commerce_number": "",
      "counterparty_address": {},
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "external_url": "",
      "group": [
        {
          "instance_description": "",
          "item": [
            {
              "billing_date": "",
              "id": 0,
              "quantity": 0,
              "total_vat_exclusive": {},
              "total_vat_inclusive": {},
              "type_description": "",
              "type_description_translated": "",
              "unit_vat_exclusive": {},
              "unit_vat_inclusive": {},
              "vat": 0
            }
          ],
          "product_vat_exclusive": {},
          "product_vat_inclusive": {},
          "type": "",
          "type_description": "",
          "type_description_translated": ""
        }
      ],
      "id": 0,
      "invoice_date": "",
      "invoice_number": "",
      "request_reference_split_the_bill": [
        {
          "id": 0,
          "type": ""
        }
      ],
      "status": "",
      "total_vat": {},
      "total_vat_exclusive": {},
      "total_vat_inclusive": {},
      "updated": "",
      "vat_number": ""
    },
    "DraftPayment": {
      "entries": [
        {
          "alias": {},
          "amount": {},
          "attachment": [
            {
              "id": 0,
              "monetary_account_id": 0
            }
          ],
          "counterparty_alias": {},
          "description": "",
          "id": 0,
          "merchant_reference": "",
          "type": ""
        }
      ],
      "number_of_required_accepts": 0,
      "previous_updated_timestamp": "",
      "schedule": {
        "object": {
          "Payment": {
            "address_billing": {},
            "address_shipping": {},
            "alias": {},
            "allow_bunqto": false,
            "amount": {},
            "attachment": [
              {}
            ],
            "balance_after_mutation": {},
            "batch_id": 0,
            "bunqto_expiry": "",
            "bunqto_share_url": "",
            "bunqto_status": "",
            "bunqto_sub_status": "",
            "bunqto_time_responded": "",
            "counterparty_alias": {},
            "created": "",
            "description": "",
            "geolocation": {},
            "id": 0,
            "merchant_reference": "",
            "monetary_account_id": 0,
            "payment_auto_allocate_instance": {
              "created": "",
              "error_message": [],
              "id": 0,
              "payment_auto_allocate_id": 0,
              "payment_batch": {
                "payments": {
                  "Payment": []
                }
              },
              "payment_id": 0,
              "status": "",
              "updated": ""
            },
            "request_reference_split_the_bill": [
              {}
            ],
            "scheduled_id": 0,
            "sub_type": "",
            "type": "",
            "updated": ""
          },
          "PaymentBatch": {}
        },
        "recurrence_size": 0,
        "recurrence_unit": "",
        "status": "",
        "time_end": "",
        "time_start": ""
      },
      "status": ""
    },
    "MasterCardAction": {
      "alias": {},
      "all_mastercard_action_refund": [
        {
          "additional_information": {
            "attachment": [
              {
                "id": 0
              }
            ],
            "category": "",
            "comment": "",
            "reason": "",
            "terms_and_conditions": ""
          },
          "alias": {},
          "amount": {},
          "attachment": [
            {}
          ],
          "category": "",
          "comment": "",
          "counterparty_alias": {},
          "created": "",
          "description": "",
          "id": 0,
          "label_card": {
            "expiry_date": "",
            "label_user": {},
            "second_line": "",
            "status": "",
            "type": "",
            "uuid": ""
          },
          "label_user_creator": {},
          "mastercard_action_id": 0,
          "reason": "",
          "reference_mastercard_action_event": [
            {
              "event_id": 0
            }
          ],
          "status": "",
          "status_description": "",
          "status_description_translated": "",
          "status_together_url": "",
          "sub_type": "",
          "terms_and_conditions": "",
          "time_refund": "",
          "type": "",
          "updated": ""
        }
      ],
      "amount_billing": {},
      "amount_converted": {},
      "amount_fee": {},
      "amount_local": {},
      "amount_original_billing": {},
      "amount_original_local": {},
      "applied_limit": "",
      "authorisation_status": "",
      "authorisation_type": "",
      "card_authorisation_id_response": "",
      "card_id": 0,
      "city": "",
      "clearing_expiry_time": "",
      "clearing_status": "",
      "counterparty_alias": {},
      "decision": "",
      "decision_description": "",
      "decision_description_translated": "",
      "decision_together_url": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "id": 0,
      "label_card": {},
      "maturity_date": "",
      "monetary_account_id": 0,
      "pan_entry_mode_user": "",
      "payment_status": "",
      "pos_card_holder_presence": "",
      "pos_card_presence": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "reservation_expiry_time": "",
      "secure_code_id": 0,
      "settlement_status": "",
      "token_status": "",
      "wallet_provider_id": ""
    },
    "Payment": {},
    "PaymentBatch": {},
    "RequestResponse": {
      "address_billing": {},
      "address_shipping": {},
      "alias": {},
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "content_type": "",
          "description": "",
          "urls": [
            {
              "type": "",
              "url": ""
            }
          ]
        }
      ],
      "counterparty_alias": {},
      "created": "",
      "credit_scheme_identifier": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "mandate_identifier": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "require_address": "",
      "status": "",
      "sub_type": "",
      "time_expiry": "",
      "time_refund_requested": "",
      "time_refunded": "",
      "time_responded": "",
      "type": "",
      "updated": "",
      "user_refund_requested": {}
    },
    "ScheduleInstance": {
      "error_message": [],
      "request_reference_split_the_bill": [
        {}
      ],
      "result_object": {
        "Payment": {},
        "PaymentBatch": {}
      },
      "scheduled_object": {},
      "state": "",
      "time_end": "",
      "time_start": ""
    },
    "TransferwisePayment": {
      "alias": {},
      "amount_source": {},
      "amount_target": {},
      "counterparty_alias": {},
      "monetary_account_id": "",
      "pay_in_reference": "",
      "quote": {
        "amount_fee": {},
        "amount_source": {},
        "amount_target": {},
        "created": "",
        "currency_source": "",
        "currency_target": "",
        "id": 0,
        "quote_id": "",
        "rate": "",
        "time_delivery_estimate": "",
        "time_expiry": "",
        "updated": ""
      },
      "rate": "",
      "recipient_id": "",
      "reference": "",
      "status": "",
      "status_transferwise": "",
      "status_transferwise_issue": "",
      "sub_status": "",
      "time_delivery_estimate": ""
    },
    "WhitelistResult": {
      "error_message": [],
      "id": 0,
      "monetary_account_paying_id": 0,
      "object": {
        "draftPayment": {},
        "id": 0,
        "requestResponse": {}
      },
      "request_reference_split_the_bill": [
        {}
      ],
      "status": "",
      "sub_status": "",
      "whitelist": {}
    }
  },
  "require_address": "",
  "scheduled_id": 0,
  "status": "",
  "time_expiry": "",
  "time_responded": "",
  "updated": "",
  "user_alias_created": {},
  "user_alias_revoked": {},
  "want_tip": false
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"allow_amount_higher\": false,\n  \"allow_amount_lower\": false,\n  \"allow_bunqme\": false,\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"id\": 0\n    }\n  ],\n  \"batch_id\": 0,\n  \"bunqme_share_url\": \"\",\n  \"counterparty_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {},\n      \"alias\": {},\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {},\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {},\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"require_address\": \"\",\n  \"scheduled_id\": 0,\n  \"status\": \"\",\n  \"time_expiry\": \"\",\n  \"time_responded\": \"\",\n  \"updated\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {},\n  \"want_tip\": false\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry"

payload = {
    "address_billing": {
        "city": "",
        "country": "",
        "extra": "",
        "house_number": "",
        "is_user_address_updated": False,
        "mailbox_name": "",
        "po_box": "",
        "postal_code": "",
        "province": "",
        "street": ""
    },
    "address_shipping": {},
    "allow_amount_higher": False,
    "allow_amount_lower": False,
    "allow_bunqme": False,
    "amount_inquired": {
        "currency": "",
        "value": ""
    },
    "amount_responded": {},
    "attachment": [{ "id": 0 }],
    "batch_id": 0,
    "bunqme_share_url": "",
    "counterparty_alias": {
        "avatar": {
            "anchor_uuid": "",
            "image": [
                {
                    "attachment_public_uuid": "",
                    "content_type": "",
                    "height": 0,
                    "width": 0
                }
            ],
            "style": "",
            "uuid": ""
        },
        "bunq_me": {
            "name": "",
            "service": "",
            "type": "",
            "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": False,
        "label_user": {
            "avatar": {},
            "country": "",
            "display_name": "",
            "public_nick_name": "",
            "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
    },
    "created": "",
    "description": "",
    "event_id": 0,
    "geolocation": {
        "altitude": 0,
        "latitude": 0,
        "longitude": 0,
        "radius": 0
    },
    "id": 0,
    "merchant_reference": "",
    "minimum_age": 0,
    "monetary_account_id": 0,
    "redirect_url": "",
    "reference_split_the_bill": {
        "BillingInvoice": {
            "address": {},
            "alias": {},
            "category": "",
            "chamber_of_commerce_number": "",
            "counterparty_address": {},
            "counterparty_alias": {},
            "created": "",
            "description": "",
            "external_url": "",
            "group": [
                {
                    "instance_description": "",
                    "item": [
                        {
                            "billing_date": "",
                            "id": 0,
                            "quantity": 0,
                            "total_vat_exclusive": {},
                            "total_vat_inclusive": {},
                            "type_description": "",
                            "type_description_translated": "",
                            "unit_vat_exclusive": {},
                            "unit_vat_inclusive": {},
                            "vat": 0
                        }
                    ],
                    "product_vat_exclusive": {},
                    "product_vat_inclusive": {},
                    "type": "",
                    "type_description": "",
                    "type_description_translated": ""
                }
            ],
            "id": 0,
            "invoice_date": "",
            "invoice_number": "",
            "request_reference_split_the_bill": [
                {
                    "id": 0,
                    "type": ""
                }
            ],
            "status": "",
            "total_vat": {},
            "total_vat_exclusive": {},
            "total_vat_inclusive": {},
            "updated": "",
            "vat_number": ""
        },
        "DraftPayment": {
            "entries": [
                {
                    "alias": {},
                    "amount": {},
                    "attachment": [
                        {
                            "id": 0,
                            "monetary_account_id": 0
                        }
                    ],
                    "counterparty_alias": {},
                    "description": "",
                    "id": 0,
                    "merchant_reference": "",
                    "type": ""
                }
            ],
            "number_of_required_accepts": 0,
            "previous_updated_timestamp": "",
            "schedule": {
                "object": {
                    "Payment": {
                        "address_billing": {},
                        "address_shipping": {},
                        "alias": {},
                        "allow_bunqto": False,
                        "amount": {},
                        "attachment": [{}],
                        "balance_after_mutation": {},
                        "batch_id": 0,
                        "bunqto_expiry": "",
                        "bunqto_share_url": "",
                        "bunqto_status": "",
                        "bunqto_sub_status": "",
                        "bunqto_time_responded": "",
                        "counterparty_alias": {},
                        "created": "",
                        "description": "",
                        "geolocation": {},
                        "id": 0,
                        "merchant_reference": "",
                        "monetary_account_id": 0,
                        "payment_auto_allocate_instance": {
                            "created": "",
                            "error_message": [],
                            "id": 0,
                            "payment_auto_allocate_id": 0,
                            "payment_batch": { "payments": { "Payment": [] } },
                            "payment_id": 0,
                            "status": "",
                            "updated": ""
                        },
                        "request_reference_split_the_bill": [{}],
                        "scheduled_id": 0,
                        "sub_type": "",
                        "type": "",
                        "updated": ""
                    },
                    "PaymentBatch": {}
                },
                "recurrence_size": 0,
                "recurrence_unit": "",
                "status": "",
                "time_end": "",
                "time_start": ""
            },
            "status": ""
        },
        "MasterCardAction": {
            "alias": {},
            "all_mastercard_action_refund": [
                {
                    "additional_information": {
                        "attachment": [{ "id": 0 }],
                        "category": "",
                        "comment": "",
                        "reason": "",
                        "terms_and_conditions": ""
                    },
                    "alias": {},
                    "amount": {},
                    "attachment": [{}],
                    "category": "",
                    "comment": "",
                    "counterparty_alias": {},
                    "created": "",
                    "description": "",
                    "id": 0,
                    "label_card": {
                        "expiry_date": "",
                        "label_user": {},
                        "second_line": "",
                        "status": "",
                        "type": "",
                        "uuid": ""
                    },
                    "label_user_creator": {},
                    "mastercard_action_id": 0,
                    "reason": "",
                    "reference_mastercard_action_event": [{ "event_id": 0 }],
                    "status": "",
                    "status_description": "",
                    "status_description_translated": "",
                    "status_together_url": "",
                    "sub_type": "",
                    "terms_and_conditions": "",
                    "time_refund": "",
                    "type": "",
                    "updated": ""
                }
            ],
            "amount_billing": {},
            "amount_converted": {},
            "amount_fee": {},
            "amount_local": {},
            "amount_original_billing": {},
            "amount_original_local": {},
            "applied_limit": "",
            "authorisation_status": "",
            "authorisation_type": "",
            "card_authorisation_id_response": "",
            "card_id": 0,
            "city": "",
            "clearing_expiry_time": "",
            "clearing_status": "",
            "counterparty_alias": {},
            "decision": "",
            "decision_description": "",
            "decision_description_translated": "",
            "decision_together_url": "",
            "description": "",
            "eligible_whitelist_id": 0,
            "id": 0,
            "label_card": {},
            "maturity_date": "",
            "monetary_account_id": 0,
            "pan_entry_mode_user": "",
            "payment_status": "",
            "pos_card_holder_presence": "",
            "pos_card_presence": "",
            "request_reference_split_the_bill": [{}],
            "reservation_expiry_time": "",
            "secure_code_id": 0,
            "settlement_status": "",
            "token_status": "",
            "wallet_provider_id": ""
        },
        "Payment": {},
        "PaymentBatch": {},
        "RequestResponse": {
            "address_billing": {},
            "address_shipping": {},
            "alias": {},
            "amount_inquired": {},
            "amount_responded": {},
            "attachment": [
                {
                    "content_type": "",
                    "description": "",
                    "urls": [
                        {
                            "type": "",
                            "url": ""
                        }
                    ]
                }
            ],
            "counterparty_alias": {},
            "created": "",
            "credit_scheme_identifier": "",
            "description": "",
            "eligible_whitelist_id": 0,
            "event_id": 0,
            "geolocation": {},
            "id": 0,
            "mandate_identifier": "",
            "minimum_age": 0,
            "monetary_account_id": 0,
            "redirect_url": "",
            "request_reference_split_the_bill": [{}],
            "require_address": "",
            "status": "",
            "sub_type": "",
            "time_expiry": "",
            "time_refund_requested": "",
            "time_refunded": "",
            "time_responded": "",
            "type": "",
            "updated": "",
            "user_refund_requested": {}
        },
        "ScheduleInstance": {
            "error_message": [],
            "request_reference_split_the_bill": [{}],
            "result_object": {
                "Payment": {},
                "PaymentBatch": {}
            },
            "scheduled_object": {},
            "state": "",
            "time_end": "",
            "time_start": ""
        },
        "TransferwisePayment": {
            "alias": {},
            "amount_source": {},
            "amount_target": {},
            "counterparty_alias": {},
            "monetary_account_id": "",
            "pay_in_reference": "",
            "quote": {
                "amount_fee": {},
                "amount_source": {},
                "amount_target": {},
                "created": "",
                "currency_source": "",
                "currency_target": "",
                "id": 0,
                "quote_id": "",
                "rate": "",
                "time_delivery_estimate": "",
                "time_expiry": "",
                "updated": ""
            },
            "rate": "",
            "recipient_id": "",
            "reference": "",
            "status": "",
            "status_transferwise": "",
            "status_transferwise_issue": "",
            "sub_status": "",
            "time_delivery_estimate": ""
        },
        "WhitelistResult": {
            "error_message": [],
            "id": 0,
            "monetary_account_paying_id": 0,
            "object": {
                "draftPayment": {},
                "id": 0,
                "requestResponse": {}
            },
            "request_reference_split_the_bill": [{}],
            "status": "",
            "sub_status": "",
            "whitelist": {}
        }
    },
    "require_address": "",
    "scheduled_id": 0,
    "status": "",
    "time_expiry": "",
    "time_responded": "",
    "updated": "",
    "user_alias_created": {},
    "user_alias_revoked": {},
    "want_tip": False
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry"

payload <- "{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"allow_amount_higher\": false,\n  \"allow_amount_lower\": false,\n  \"allow_bunqme\": false,\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"id\": 0\n    }\n  ],\n  \"batch_id\": 0,\n  \"bunqme_share_url\": \"\",\n  \"counterparty_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {},\n      \"alias\": {},\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {},\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {},\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"require_address\": \"\",\n  \"scheduled_id\": 0,\n  \"status\": \"\",\n  \"time_expiry\": \"\",\n  \"time_responded\": \"\",\n  \"updated\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {},\n  \"want_tip\": false\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"allow_amount_higher\": false,\n  \"allow_amount_lower\": false,\n  \"allow_bunqme\": false,\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"id\": 0\n    }\n  ],\n  \"batch_id\": 0,\n  \"bunqme_share_url\": \"\",\n  \"counterparty_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {},\n      \"alias\": {},\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {},\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {},\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"require_address\": \"\",\n  \"scheduled_id\": 0,\n  \"status\": \"\",\n  \"time_expiry\": \"\",\n  \"time_responded\": \"\",\n  \"updated\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {},\n  \"want_tip\": false\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"allow_amount_higher\": false,\n  \"allow_amount_lower\": false,\n  \"allow_bunqme\": false,\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"id\": 0\n    }\n  ],\n  \"batch_id\": 0,\n  \"bunqme_share_url\": \"\",\n  \"counterparty_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {},\n      \"alias\": {},\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {},\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {},\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"require_address\": \"\",\n  \"scheduled_id\": 0,\n  \"status\": \"\",\n  \"time_expiry\": \"\",\n  \"time_responded\": \"\",\n  \"updated\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {},\n  \"want_tip\": false\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry";

    let payload = json!({
        "address_billing": json!({
            "city": "",
            "country": "",
            "extra": "",
            "house_number": "",
            "is_user_address_updated": false,
            "mailbox_name": "",
            "po_box": "",
            "postal_code": "",
            "province": "",
            "street": ""
        }),
        "address_shipping": json!({}),
        "allow_amount_higher": false,
        "allow_amount_lower": false,
        "allow_bunqme": false,
        "amount_inquired": json!({
            "currency": "",
            "value": ""
        }),
        "amount_responded": json!({}),
        "attachment": (json!({"id": 0})),
        "batch_id": 0,
        "bunqme_share_url": "",
        "counterparty_alias": json!({
            "avatar": json!({
                "anchor_uuid": "",
                "image": (
                    json!({
                        "attachment_public_uuid": "",
                        "content_type": "",
                        "height": 0,
                        "width": 0
                    })
                ),
                "style": "",
                "uuid": ""
            }),
            "bunq_me": json!({
                "name": "",
                "service": "",
                "type": "",
                "value": ""
            }),
            "country": "",
            "display_name": "",
            "iban": "",
            "is_light": false,
            "label_user": json!({
                "avatar": json!({}),
                "country": "",
                "display_name": "",
                "public_nick_name": "",
                "uuid": ""
            }),
            "merchant_category_code": "",
            "swift_account_number": "",
            "swift_bic": "",
            "transferwise_account_number": "",
            "transferwise_bank_code": ""
        }),
        "created": "",
        "description": "",
        "event_id": 0,
        "geolocation": json!({
            "altitude": 0,
            "latitude": 0,
            "longitude": 0,
            "radius": 0
        }),
        "id": 0,
        "merchant_reference": "",
        "minimum_age": 0,
        "monetary_account_id": 0,
        "redirect_url": "",
        "reference_split_the_bill": json!({
            "BillingInvoice": json!({
                "address": json!({}),
                "alias": json!({}),
                "category": "",
                "chamber_of_commerce_number": "",
                "counterparty_address": json!({}),
                "counterparty_alias": json!({}),
                "created": "",
                "description": "",
                "external_url": "",
                "group": (
                    json!({
                        "instance_description": "",
                        "item": (
                            json!({
                                "billing_date": "",
                                "id": 0,
                                "quantity": 0,
                                "total_vat_exclusive": json!({}),
                                "total_vat_inclusive": json!({}),
                                "type_description": "",
                                "type_description_translated": "",
                                "unit_vat_exclusive": json!({}),
                                "unit_vat_inclusive": json!({}),
                                "vat": 0
                            })
                        ),
                        "product_vat_exclusive": json!({}),
                        "product_vat_inclusive": json!({}),
                        "type": "",
                        "type_description": "",
                        "type_description_translated": ""
                    })
                ),
                "id": 0,
                "invoice_date": "",
                "invoice_number": "",
                "request_reference_split_the_bill": (
                    json!({
                        "id": 0,
                        "type": ""
                    })
                ),
                "status": "",
                "total_vat": json!({}),
                "total_vat_exclusive": json!({}),
                "total_vat_inclusive": json!({}),
                "updated": "",
                "vat_number": ""
            }),
            "DraftPayment": json!({
                "entries": (
                    json!({
                        "alias": json!({}),
                        "amount": json!({}),
                        "attachment": (
                            json!({
                                "id": 0,
                                "monetary_account_id": 0
                            })
                        ),
                        "counterparty_alias": json!({}),
                        "description": "",
                        "id": 0,
                        "merchant_reference": "",
                        "type": ""
                    })
                ),
                "number_of_required_accepts": 0,
                "previous_updated_timestamp": "",
                "schedule": json!({
                    "object": json!({
                        "Payment": json!({
                            "address_billing": json!({}),
                            "address_shipping": json!({}),
                            "alias": json!({}),
                            "allow_bunqto": false,
                            "amount": json!({}),
                            "attachment": (json!({})),
                            "balance_after_mutation": json!({}),
                            "batch_id": 0,
                            "bunqto_expiry": "",
                            "bunqto_share_url": "",
                            "bunqto_status": "",
                            "bunqto_sub_status": "",
                            "bunqto_time_responded": "",
                            "counterparty_alias": json!({}),
                            "created": "",
                            "description": "",
                            "geolocation": json!({}),
                            "id": 0,
                            "merchant_reference": "",
                            "monetary_account_id": 0,
                            "payment_auto_allocate_instance": json!({
                                "created": "",
                                "error_message": (),
                                "id": 0,
                                "payment_auto_allocate_id": 0,
                                "payment_batch": json!({"payments": json!({"Payment": ()})}),
                                "payment_id": 0,
                                "status": "",
                                "updated": ""
                            }),
                            "request_reference_split_the_bill": (json!({})),
                            "scheduled_id": 0,
                            "sub_type": "",
                            "type": "",
                            "updated": ""
                        }),
                        "PaymentBatch": json!({})
                    }),
                    "recurrence_size": 0,
                    "recurrence_unit": "",
                    "status": "",
                    "time_end": "",
                    "time_start": ""
                }),
                "status": ""
            }),
            "MasterCardAction": json!({
                "alias": json!({}),
                "all_mastercard_action_refund": (
                    json!({
                        "additional_information": json!({
                            "attachment": (json!({"id": 0})),
                            "category": "",
                            "comment": "",
                            "reason": "",
                            "terms_and_conditions": ""
                        }),
                        "alias": json!({}),
                        "amount": json!({}),
                        "attachment": (json!({})),
                        "category": "",
                        "comment": "",
                        "counterparty_alias": json!({}),
                        "created": "",
                        "description": "",
                        "id": 0,
                        "label_card": json!({
                            "expiry_date": "",
                            "label_user": json!({}),
                            "second_line": "",
                            "status": "",
                            "type": "",
                            "uuid": ""
                        }),
                        "label_user_creator": json!({}),
                        "mastercard_action_id": 0,
                        "reason": "",
                        "reference_mastercard_action_event": (json!({"event_id": 0})),
                        "status": "",
                        "status_description": "",
                        "status_description_translated": "",
                        "status_together_url": "",
                        "sub_type": "",
                        "terms_and_conditions": "",
                        "time_refund": "",
                        "type": "",
                        "updated": ""
                    })
                ),
                "amount_billing": json!({}),
                "amount_converted": json!({}),
                "amount_fee": json!({}),
                "amount_local": json!({}),
                "amount_original_billing": json!({}),
                "amount_original_local": json!({}),
                "applied_limit": "",
                "authorisation_status": "",
                "authorisation_type": "",
                "card_authorisation_id_response": "",
                "card_id": 0,
                "city": "",
                "clearing_expiry_time": "",
                "clearing_status": "",
                "counterparty_alias": json!({}),
                "decision": "",
                "decision_description": "",
                "decision_description_translated": "",
                "decision_together_url": "",
                "description": "",
                "eligible_whitelist_id": 0,
                "id": 0,
                "label_card": json!({}),
                "maturity_date": "",
                "monetary_account_id": 0,
                "pan_entry_mode_user": "",
                "payment_status": "",
                "pos_card_holder_presence": "",
                "pos_card_presence": "",
                "request_reference_split_the_bill": (json!({})),
                "reservation_expiry_time": "",
                "secure_code_id": 0,
                "settlement_status": "",
                "token_status": "",
                "wallet_provider_id": ""
            }),
            "Payment": json!({}),
            "PaymentBatch": json!({}),
            "RequestResponse": json!({
                "address_billing": json!({}),
                "address_shipping": json!({}),
                "alias": json!({}),
                "amount_inquired": json!({}),
                "amount_responded": json!({}),
                "attachment": (
                    json!({
                        "content_type": "",
                        "description": "",
                        "urls": (
                            json!({
                                "type": "",
                                "url": ""
                            })
                        )
                    })
                ),
                "counterparty_alias": json!({}),
                "created": "",
                "credit_scheme_identifier": "",
                "description": "",
                "eligible_whitelist_id": 0,
                "event_id": 0,
                "geolocation": json!({}),
                "id": 0,
                "mandate_identifier": "",
                "minimum_age": 0,
                "monetary_account_id": 0,
                "redirect_url": "",
                "request_reference_split_the_bill": (json!({})),
                "require_address": "",
                "status": "",
                "sub_type": "",
                "time_expiry": "",
                "time_refund_requested": "",
                "time_refunded": "",
                "time_responded": "",
                "type": "",
                "updated": "",
                "user_refund_requested": json!({})
            }),
            "ScheduleInstance": json!({
                "error_message": (),
                "request_reference_split_the_bill": (json!({})),
                "result_object": json!({
                    "Payment": json!({}),
                    "PaymentBatch": json!({})
                }),
                "scheduled_object": json!({}),
                "state": "",
                "time_end": "",
                "time_start": ""
            }),
            "TransferwisePayment": json!({
                "alias": json!({}),
                "amount_source": json!({}),
                "amount_target": json!({}),
                "counterparty_alias": json!({}),
                "monetary_account_id": "",
                "pay_in_reference": "",
                "quote": json!({
                    "amount_fee": json!({}),
                    "amount_source": json!({}),
                    "amount_target": json!({}),
                    "created": "",
                    "currency_source": "",
                    "currency_target": "",
                    "id": 0,
                    "quote_id": "",
                    "rate": "",
                    "time_delivery_estimate": "",
                    "time_expiry": "",
                    "updated": ""
                }),
                "rate": "",
                "recipient_id": "",
                "reference": "",
                "status": "",
                "status_transferwise": "",
                "status_transferwise_issue": "",
                "sub_status": "",
                "time_delivery_estimate": ""
            }),
            "WhitelistResult": json!({
                "error_message": (),
                "id": 0,
                "monetary_account_paying_id": 0,
                "object": json!({
                    "draftPayment": json!({}),
                    "id": 0,
                    "requestResponse": json!({})
                }),
                "request_reference_split_the_bill": (json!({})),
                "status": "",
                "sub_status": "",
                "whitelist": json!({})
            })
        }),
        "require_address": "",
        "scheduled_id": 0,
        "status": "",
        "time_expiry": "",
        "time_responded": "",
        "updated": "",
        "user_alias_created": json!({}),
        "user_alias_revoked": json!({}),
        "want_tip": false
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "address_billing": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_shipping": {},
  "allow_amount_higher": false,
  "allow_amount_lower": false,
  "allow_bunqme": false,
  "amount_inquired": {
    "currency": "",
    "value": ""
  },
  "amount_responded": {},
  "attachment": [
    {
      "id": 0
    }
  ],
  "batch_id": 0,
  "bunqme_share_url": "",
  "counterparty_alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "created": "",
  "description": "",
  "event_id": 0,
  "geolocation": {
    "altitude": 0,
    "latitude": 0,
    "longitude": 0,
    "radius": 0
  },
  "id": 0,
  "merchant_reference": "",
  "minimum_age": 0,
  "monetary_account_id": 0,
  "redirect_url": "",
  "reference_split_the_bill": {
    "BillingInvoice": {
      "address": {},
      "alias": {},
      "category": "",
      "chamber_of_commerce_number": "",
      "counterparty_address": {},
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "external_url": "",
      "group": [
        {
          "instance_description": "",
          "item": [
            {
              "billing_date": "",
              "id": 0,
              "quantity": 0,
              "total_vat_exclusive": {},
              "total_vat_inclusive": {},
              "type_description": "",
              "type_description_translated": "",
              "unit_vat_exclusive": {},
              "unit_vat_inclusive": {},
              "vat": 0
            }
          ],
          "product_vat_exclusive": {},
          "product_vat_inclusive": {},
          "type": "",
          "type_description": "",
          "type_description_translated": ""
        }
      ],
      "id": 0,
      "invoice_date": "",
      "invoice_number": "",
      "request_reference_split_the_bill": [
        {
          "id": 0,
          "type": ""
        }
      ],
      "status": "",
      "total_vat": {},
      "total_vat_exclusive": {},
      "total_vat_inclusive": {},
      "updated": "",
      "vat_number": ""
    },
    "DraftPayment": {
      "entries": [
        {
          "alias": {},
          "amount": {},
          "attachment": [
            {
              "id": 0,
              "monetary_account_id": 0
            }
          ],
          "counterparty_alias": {},
          "description": "",
          "id": 0,
          "merchant_reference": "",
          "type": ""
        }
      ],
      "number_of_required_accepts": 0,
      "previous_updated_timestamp": "",
      "schedule": {
        "object": {
          "Payment": {
            "address_billing": {},
            "address_shipping": {},
            "alias": {},
            "allow_bunqto": false,
            "amount": {},
            "attachment": [
              {}
            ],
            "balance_after_mutation": {},
            "batch_id": 0,
            "bunqto_expiry": "",
            "bunqto_share_url": "",
            "bunqto_status": "",
            "bunqto_sub_status": "",
            "bunqto_time_responded": "",
            "counterparty_alias": {},
            "created": "",
            "description": "",
            "geolocation": {},
            "id": 0,
            "merchant_reference": "",
            "monetary_account_id": 0,
            "payment_auto_allocate_instance": {
              "created": "",
              "error_message": [],
              "id": 0,
              "payment_auto_allocate_id": 0,
              "payment_batch": {
                "payments": {
                  "Payment": []
                }
              },
              "payment_id": 0,
              "status": "",
              "updated": ""
            },
            "request_reference_split_the_bill": [
              {}
            ],
            "scheduled_id": 0,
            "sub_type": "",
            "type": "",
            "updated": ""
          },
          "PaymentBatch": {}
        },
        "recurrence_size": 0,
        "recurrence_unit": "",
        "status": "",
        "time_end": "",
        "time_start": ""
      },
      "status": ""
    },
    "MasterCardAction": {
      "alias": {},
      "all_mastercard_action_refund": [
        {
          "additional_information": {
            "attachment": [
              {
                "id": 0
              }
            ],
            "category": "",
            "comment": "",
            "reason": "",
            "terms_and_conditions": ""
          },
          "alias": {},
          "amount": {},
          "attachment": [
            {}
          ],
          "category": "",
          "comment": "",
          "counterparty_alias": {},
          "created": "",
          "description": "",
          "id": 0,
          "label_card": {
            "expiry_date": "",
            "label_user": {},
            "second_line": "",
            "status": "",
            "type": "",
            "uuid": ""
          },
          "label_user_creator": {},
          "mastercard_action_id": 0,
          "reason": "",
          "reference_mastercard_action_event": [
            {
              "event_id": 0
            }
          ],
          "status": "",
          "status_description": "",
          "status_description_translated": "",
          "status_together_url": "",
          "sub_type": "",
          "terms_and_conditions": "",
          "time_refund": "",
          "type": "",
          "updated": ""
        }
      ],
      "amount_billing": {},
      "amount_converted": {},
      "amount_fee": {},
      "amount_local": {},
      "amount_original_billing": {},
      "amount_original_local": {},
      "applied_limit": "",
      "authorisation_status": "",
      "authorisation_type": "",
      "card_authorisation_id_response": "",
      "card_id": 0,
      "city": "",
      "clearing_expiry_time": "",
      "clearing_status": "",
      "counterparty_alias": {},
      "decision": "",
      "decision_description": "",
      "decision_description_translated": "",
      "decision_together_url": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "id": 0,
      "label_card": {},
      "maturity_date": "",
      "monetary_account_id": 0,
      "pan_entry_mode_user": "",
      "payment_status": "",
      "pos_card_holder_presence": "",
      "pos_card_presence": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "reservation_expiry_time": "",
      "secure_code_id": 0,
      "settlement_status": "",
      "token_status": "",
      "wallet_provider_id": ""
    },
    "Payment": {},
    "PaymentBatch": {},
    "RequestResponse": {
      "address_billing": {},
      "address_shipping": {},
      "alias": {},
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "content_type": "",
          "description": "",
          "urls": [
            {
              "type": "",
              "url": ""
            }
          ]
        }
      ],
      "counterparty_alias": {},
      "created": "",
      "credit_scheme_identifier": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "mandate_identifier": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "require_address": "",
      "status": "",
      "sub_type": "",
      "time_expiry": "",
      "time_refund_requested": "",
      "time_refunded": "",
      "time_responded": "",
      "type": "",
      "updated": "",
      "user_refund_requested": {}
    },
    "ScheduleInstance": {
      "error_message": [],
      "request_reference_split_the_bill": [
        {}
      ],
      "result_object": {
        "Payment": {},
        "PaymentBatch": {}
      },
      "scheduled_object": {},
      "state": "",
      "time_end": "",
      "time_start": ""
    },
    "TransferwisePayment": {
      "alias": {},
      "amount_source": {},
      "amount_target": {},
      "counterparty_alias": {},
      "monetary_account_id": "",
      "pay_in_reference": "",
      "quote": {
        "amount_fee": {},
        "amount_source": {},
        "amount_target": {},
        "created": "",
        "currency_source": "",
        "currency_target": "",
        "id": 0,
        "quote_id": "",
        "rate": "",
        "time_delivery_estimate": "",
        "time_expiry": "",
        "updated": ""
      },
      "rate": "",
      "recipient_id": "",
      "reference": "",
      "status": "",
      "status_transferwise": "",
      "status_transferwise_issue": "",
      "sub_status": "",
      "time_delivery_estimate": ""
    },
    "WhitelistResult": {
      "error_message": [],
      "id": 0,
      "monetary_account_paying_id": 0,
      "object": {
        "draftPayment": {},
        "id": 0,
        "requestResponse": {}
      },
      "request_reference_split_the_bill": [
        {}
      ],
      "status": "",
      "sub_status": "",
      "whitelist": {}
    }
  },
  "require_address": "",
  "scheduled_id": 0,
  "status": "",
  "time_expiry": "",
  "time_responded": "",
  "updated": "",
  "user_alias_created": {},
  "user_alias_revoked": {},
  "want_tip": false
}'
echo '{
  "address_billing": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_shipping": {},
  "allow_amount_higher": false,
  "allow_amount_lower": false,
  "allow_bunqme": false,
  "amount_inquired": {
    "currency": "",
    "value": ""
  },
  "amount_responded": {},
  "attachment": [
    {
      "id": 0
    }
  ],
  "batch_id": 0,
  "bunqme_share_url": "",
  "counterparty_alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "created": "",
  "description": "",
  "event_id": 0,
  "geolocation": {
    "altitude": 0,
    "latitude": 0,
    "longitude": 0,
    "radius": 0
  },
  "id": 0,
  "merchant_reference": "",
  "minimum_age": 0,
  "monetary_account_id": 0,
  "redirect_url": "",
  "reference_split_the_bill": {
    "BillingInvoice": {
      "address": {},
      "alias": {},
      "category": "",
      "chamber_of_commerce_number": "",
      "counterparty_address": {},
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "external_url": "",
      "group": [
        {
          "instance_description": "",
          "item": [
            {
              "billing_date": "",
              "id": 0,
              "quantity": 0,
              "total_vat_exclusive": {},
              "total_vat_inclusive": {},
              "type_description": "",
              "type_description_translated": "",
              "unit_vat_exclusive": {},
              "unit_vat_inclusive": {},
              "vat": 0
            }
          ],
          "product_vat_exclusive": {},
          "product_vat_inclusive": {},
          "type": "",
          "type_description": "",
          "type_description_translated": ""
        }
      ],
      "id": 0,
      "invoice_date": "",
      "invoice_number": "",
      "request_reference_split_the_bill": [
        {
          "id": 0,
          "type": ""
        }
      ],
      "status": "",
      "total_vat": {},
      "total_vat_exclusive": {},
      "total_vat_inclusive": {},
      "updated": "",
      "vat_number": ""
    },
    "DraftPayment": {
      "entries": [
        {
          "alias": {},
          "amount": {},
          "attachment": [
            {
              "id": 0,
              "monetary_account_id": 0
            }
          ],
          "counterparty_alias": {},
          "description": "",
          "id": 0,
          "merchant_reference": "",
          "type": ""
        }
      ],
      "number_of_required_accepts": 0,
      "previous_updated_timestamp": "",
      "schedule": {
        "object": {
          "Payment": {
            "address_billing": {},
            "address_shipping": {},
            "alias": {},
            "allow_bunqto": false,
            "amount": {},
            "attachment": [
              {}
            ],
            "balance_after_mutation": {},
            "batch_id": 0,
            "bunqto_expiry": "",
            "bunqto_share_url": "",
            "bunqto_status": "",
            "bunqto_sub_status": "",
            "bunqto_time_responded": "",
            "counterparty_alias": {},
            "created": "",
            "description": "",
            "geolocation": {},
            "id": 0,
            "merchant_reference": "",
            "monetary_account_id": 0,
            "payment_auto_allocate_instance": {
              "created": "",
              "error_message": [],
              "id": 0,
              "payment_auto_allocate_id": 0,
              "payment_batch": {
                "payments": {
                  "Payment": []
                }
              },
              "payment_id": 0,
              "status": "",
              "updated": ""
            },
            "request_reference_split_the_bill": [
              {}
            ],
            "scheduled_id": 0,
            "sub_type": "",
            "type": "",
            "updated": ""
          },
          "PaymentBatch": {}
        },
        "recurrence_size": 0,
        "recurrence_unit": "",
        "status": "",
        "time_end": "",
        "time_start": ""
      },
      "status": ""
    },
    "MasterCardAction": {
      "alias": {},
      "all_mastercard_action_refund": [
        {
          "additional_information": {
            "attachment": [
              {
                "id": 0
              }
            ],
            "category": "",
            "comment": "",
            "reason": "",
            "terms_and_conditions": ""
          },
          "alias": {},
          "amount": {},
          "attachment": [
            {}
          ],
          "category": "",
          "comment": "",
          "counterparty_alias": {},
          "created": "",
          "description": "",
          "id": 0,
          "label_card": {
            "expiry_date": "",
            "label_user": {},
            "second_line": "",
            "status": "",
            "type": "",
            "uuid": ""
          },
          "label_user_creator": {},
          "mastercard_action_id": 0,
          "reason": "",
          "reference_mastercard_action_event": [
            {
              "event_id": 0
            }
          ],
          "status": "",
          "status_description": "",
          "status_description_translated": "",
          "status_together_url": "",
          "sub_type": "",
          "terms_and_conditions": "",
          "time_refund": "",
          "type": "",
          "updated": ""
        }
      ],
      "amount_billing": {},
      "amount_converted": {},
      "amount_fee": {},
      "amount_local": {},
      "amount_original_billing": {},
      "amount_original_local": {},
      "applied_limit": "",
      "authorisation_status": "",
      "authorisation_type": "",
      "card_authorisation_id_response": "",
      "card_id": 0,
      "city": "",
      "clearing_expiry_time": "",
      "clearing_status": "",
      "counterparty_alias": {},
      "decision": "",
      "decision_description": "",
      "decision_description_translated": "",
      "decision_together_url": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "id": 0,
      "label_card": {},
      "maturity_date": "",
      "monetary_account_id": 0,
      "pan_entry_mode_user": "",
      "payment_status": "",
      "pos_card_holder_presence": "",
      "pos_card_presence": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "reservation_expiry_time": "",
      "secure_code_id": 0,
      "settlement_status": "",
      "token_status": "",
      "wallet_provider_id": ""
    },
    "Payment": {},
    "PaymentBatch": {},
    "RequestResponse": {
      "address_billing": {},
      "address_shipping": {},
      "alias": {},
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "content_type": "",
          "description": "",
          "urls": [
            {
              "type": "",
              "url": ""
            }
          ]
        }
      ],
      "counterparty_alias": {},
      "created": "",
      "credit_scheme_identifier": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "mandate_identifier": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "require_address": "",
      "status": "",
      "sub_type": "",
      "time_expiry": "",
      "time_refund_requested": "",
      "time_refunded": "",
      "time_responded": "",
      "type": "",
      "updated": "",
      "user_refund_requested": {}
    },
    "ScheduleInstance": {
      "error_message": [],
      "request_reference_split_the_bill": [
        {}
      ],
      "result_object": {
        "Payment": {},
        "PaymentBatch": {}
      },
      "scheduled_object": {},
      "state": "",
      "time_end": "",
      "time_start": ""
    },
    "TransferwisePayment": {
      "alias": {},
      "amount_source": {},
      "amount_target": {},
      "counterparty_alias": {},
      "monetary_account_id": "",
      "pay_in_reference": "",
      "quote": {
        "amount_fee": {},
        "amount_source": {},
        "amount_target": {},
        "created": "",
        "currency_source": "",
        "currency_target": "",
        "id": 0,
        "quote_id": "",
        "rate": "",
        "time_delivery_estimate": "",
        "time_expiry": "",
        "updated": ""
      },
      "rate": "",
      "recipient_id": "",
      "reference": "",
      "status": "",
      "status_transferwise": "",
      "status_transferwise_issue": "",
      "sub_status": "",
      "time_delivery_estimate": ""
    },
    "WhitelistResult": {
      "error_message": [],
      "id": 0,
      "monetary_account_paying_id": 0,
      "object": {
        "draftPayment": {},
        "id": 0,
        "requestResponse": {}
      },
      "request_reference_split_the_bill": [
        {}
      ],
      "status": "",
      "sub_status": "",
      "whitelist": {}
    }
  },
  "require_address": "",
  "scheduled_id": 0,
  "status": "",
  "time_expiry": "",
  "time_responded": "",
  "updated": "",
  "user_alias_created": {},
  "user_alias_revoked": {},
  "want_tip": false
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "address_billing": {\n    "city": "",\n    "country": "",\n    "extra": "",\n    "house_number": "",\n    "is_user_address_updated": false,\n    "mailbox_name": "",\n    "po_box": "",\n    "postal_code": "",\n    "province": "",\n    "street": ""\n  },\n  "address_shipping": {},\n  "allow_amount_higher": false,\n  "allow_amount_lower": false,\n  "allow_bunqme": false,\n  "amount_inquired": {\n    "currency": "",\n    "value": ""\n  },\n  "amount_responded": {},\n  "attachment": [\n    {\n      "id": 0\n    }\n  ],\n  "batch_id": 0,\n  "bunqme_share_url": "",\n  "counterparty_alias": {\n    "avatar": {\n      "anchor_uuid": "",\n      "image": [\n        {\n          "attachment_public_uuid": "",\n          "content_type": "",\n          "height": 0,\n          "width": 0\n        }\n      ],\n      "style": "",\n      "uuid": ""\n    },\n    "bunq_me": {\n      "name": "",\n      "service": "",\n      "type": "",\n      "value": ""\n    },\n    "country": "",\n    "display_name": "",\n    "iban": "",\n    "is_light": false,\n    "label_user": {\n      "avatar": {},\n      "country": "",\n      "display_name": "",\n      "public_nick_name": "",\n      "uuid": ""\n    },\n    "merchant_category_code": "",\n    "swift_account_number": "",\n    "swift_bic": "",\n    "transferwise_account_number": "",\n    "transferwise_bank_code": ""\n  },\n  "created": "",\n  "description": "",\n  "event_id": 0,\n  "geolocation": {\n    "altitude": 0,\n    "latitude": 0,\n    "longitude": 0,\n    "radius": 0\n  },\n  "id": 0,\n  "merchant_reference": "",\n  "minimum_age": 0,\n  "monetary_account_id": 0,\n  "redirect_url": "",\n  "reference_split_the_bill": {\n    "BillingInvoice": {\n      "address": {},\n      "alias": {},\n      "category": "",\n      "chamber_of_commerce_number": "",\n      "counterparty_address": {},\n      "counterparty_alias": {},\n      "created": "",\n      "description": "",\n      "external_url": "",\n      "group": [\n        {\n          "instance_description": "",\n          "item": [\n            {\n              "billing_date": "",\n              "id": 0,\n              "quantity": 0,\n              "total_vat_exclusive": {},\n              "total_vat_inclusive": {},\n              "type_description": "",\n              "type_description_translated": "",\n              "unit_vat_exclusive": {},\n              "unit_vat_inclusive": {},\n              "vat": 0\n            }\n          ],\n          "product_vat_exclusive": {},\n          "product_vat_inclusive": {},\n          "type": "",\n          "type_description": "",\n          "type_description_translated": ""\n        }\n      ],\n      "id": 0,\n      "invoice_date": "",\n      "invoice_number": "",\n      "request_reference_split_the_bill": [\n        {\n          "id": 0,\n          "type": ""\n        }\n      ],\n      "status": "",\n      "total_vat": {},\n      "total_vat_exclusive": {},\n      "total_vat_inclusive": {},\n      "updated": "",\n      "vat_number": ""\n    },\n    "DraftPayment": {\n      "entries": [\n        {\n          "alias": {},\n          "amount": {},\n          "attachment": [\n            {\n              "id": 0,\n              "monetary_account_id": 0\n            }\n          ],\n          "counterparty_alias": {},\n          "description": "",\n          "id": 0,\n          "merchant_reference": "",\n          "type": ""\n        }\n      ],\n      "number_of_required_accepts": 0,\n      "previous_updated_timestamp": "",\n      "schedule": {\n        "object": {\n          "Payment": {\n            "address_billing": {},\n            "address_shipping": {},\n            "alias": {},\n            "allow_bunqto": false,\n            "amount": {},\n            "attachment": [\n              {}\n            ],\n            "balance_after_mutation": {},\n            "batch_id": 0,\n            "bunqto_expiry": "",\n            "bunqto_share_url": "",\n            "bunqto_status": "",\n            "bunqto_sub_status": "",\n            "bunqto_time_responded": "",\n            "counterparty_alias": {},\n            "created": "",\n            "description": "",\n            "geolocation": {},\n            "id": 0,\n            "merchant_reference": "",\n            "monetary_account_id": 0,\n            "payment_auto_allocate_instance": {\n              "created": "",\n              "error_message": [],\n              "id": 0,\n              "payment_auto_allocate_id": 0,\n              "payment_batch": {\n                "payments": {\n                  "Payment": []\n                }\n              },\n              "payment_id": 0,\n              "status": "",\n              "updated": ""\n            },\n            "request_reference_split_the_bill": [\n              {}\n            ],\n            "scheduled_id": 0,\n            "sub_type": "",\n            "type": "",\n            "updated": ""\n          },\n          "PaymentBatch": {}\n        },\n        "recurrence_size": 0,\n        "recurrence_unit": "",\n        "status": "",\n        "time_end": "",\n        "time_start": ""\n      },\n      "status": ""\n    },\n    "MasterCardAction": {\n      "alias": {},\n      "all_mastercard_action_refund": [\n        {\n          "additional_information": {\n            "attachment": [\n              {\n                "id": 0\n              }\n            ],\n            "category": "",\n            "comment": "",\n            "reason": "",\n            "terms_and_conditions": ""\n          },\n          "alias": {},\n          "amount": {},\n          "attachment": [\n            {}\n          ],\n          "category": "",\n          "comment": "",\n          "counterparty_alias": {},\n          "created": "",\n          "description": "",\n          "id": 0,\n          "label_card": {\n            "expiry_date": "",\n            "label_user": {},\n            "second_line": "",\n            "status": "",\n            "type": "",\n            "uuid": ""\n          },\n          "label_user_creator": {},\n          "mastercard_action_id": 0,\n          "reason": "",\n          "reference_mastercard_action_event": [\n            {\n              "event_id": 0\n            }\n          ],\n          "status": "",\n          "status_description": "",\n          "status_description_translated": "",\n          "status_together_url": "",\n          "sub_type": "",\n          "terms_and_conditions": "",\n          "time_refund": "",\n          "type": "",\n          "updated": ""\n        }\n      ],\n      "amount_billing": {},\n      "amount_converted": {},\n      "amount_fee": {},\n      "amount_local": {},\n      "amount_original_billing": {},\n      "amount_original_local": {},\n      "applied_limit": "",\n      "authorisation_status": "",\n      "authorisation_type": "",\n      "card_authorisation_id_response": "",\n      "card_id": 0,\n      "city": "",\n      "clearing_expiry_time": "",\n      "clearing_status": "",\n      "counterparty_alias": {},\n      "decision": "",\n      "decision_description": "",\n      "decision_description_translated": "",\n      "decision_together_url": "",\n      "description": "",\n      "eligible_whitelist_id": 0,\n      "id": 0,\n      "label_card": {},\n      "maturity_date": "",\n      "monetary_account_id": 0,\n      "pan_entry_mode_user": "",\n      "payment_status": "",\n      "pos_card_holder_presence": "",\n      "pos_card_presence": "",\n      "request_reference_split_the_bill": [\n        {}\n      ],\n      "reservation_expiry_time": "",\n      "secure_code_id": 0,\n      "settlement_status": "",\n      "token_status": "",\n      "wallet_provider_id": ""\n    },\n    "Payment": {},\n    "PaymentBatch": {},\n    "RequestResponse": {\n      "address_billing": {},\n      "address_shipping": {},\n      "alias": {},\n      "amount_inquired": {},\n      "amount_responded": {},\n      "attachment": [\n        {\n          "content_type": "",\n          "description": "",\n          "urls": [\n            {\n              "type": "",\n              "url": ""\n            }\n          ]\n        }\n      ],\n      "counterparty_alias": {},\n      "created": "",\n      "credit_scheme_identifier": "",\n      "description": "",\n      "eligible_whitelist_id": 0,\n      "event_id": 0,\n      "geolocation": {},\n      "id": 0,\n      "mandate_identifier": "",\n      "minimum_age": 0,\n      "monetary_account_id": 0,\n      "redirect_url": "",\n      "request_reference_split_the_bill": [\n        {}\n      ],\n      "require_address": "",\n      "status": "",\n      "sub_type": "",\n      "time_expiry": "",\n      "time_refund_requested": "",\n      "time_refunded": "",\n      "time_responded": "",\n      "type": "",\n      "updated": "",\n      "user_refund_requested": {}\n    },\n    "ScheduleInstance": {\n      "error_message": [],\n      "request_reference_split_the_bill": [\n        {}\n      ],\n      "result_object": {\n        "Payment": {},\n        "PaymentBatch": {}\n      },\n      "scheduled_object": {},\n      "state": "",\n      "time_end": "",\n      "time_start": ""\n    },\n    "TransferwisePayment": {\n      "alias": {},\n      "amount_source": {},\n      "amount_target": {},\n      "counterparty_alias": {},\n      "monetary_account_id": "",\n      "pay_in_reference": "",\n      "quote": {\n        "amount_fee": {},\n        "amount_source": {},\n        "amount_target": {},\n        "created": "",\n        "currency_source": "",\n        "currency_target": "",\n        "id": 0,\n        "quote_id": "",\n        "rate": "",\n        "time_delivery_estimate": "",\n        "time_expiry": "",\n        "updated": ""\n      },\n      "rate": "",\n      "recipient_id": "",\n      "reference": "",\n      "status": "",\n      "status_transferwise": "",\n      "status_transferwise_issue": "",\n      "sub_status": "",\n      "time_delivery_estimate": ""\n    },\n    "WhitelistResult": {\n      "error_message": [],\n      "id": 0,\n      "monetary_account_paying_id": 0,\n      "object": {\n        "draftPayment": {},\n        "id": 0,\n        "requestResponse": {}\n      },\n      "request_reference_split_the_bill": [\n        {}\n      ],\n      "status": "",\n      "sub_status": "",\n      "whitelist": {}\n    }\n  },\n  "require_address": "",\n  "scheduled_id": 0,\n  "status": "",\n  "time_expiry": "",\n  "time_responded": "",\n  "updated": "",\n  "user_alias_created": {},\n  "user_alias_revoked": {},\n  "want_tip": false\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "address_billing": [
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  ],
  "address_shipping": [],
  "allow_amount_higher": false,
  "allow_amount_lower": false,
  "allow_bunqme": false,
  "amount_inquired": [
    "currency": "",
    "value": ""
  ],
  "amount_responded": [],
  "attachment": [["id": 0]],
  "batch_id": 0,
  "bunqme_share_url": "",
  "counterparty_alias": [
    "avatar": [
      "anchor_uuid": "",
      "image": [
        [
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        ]
      ],
      "style": "",
      "uuid": ""
    ],
    "bunq_me": [
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    ],
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": [
      "avatar": [],
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    ],
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  ],
  "created": "",
  "description": "",
  "event_id": 0,
  "geolocation": [
    "altitude": 0,
    "latitude": 0,
    "longitude": 0,
    "radius": 0
  ],
  "id": 0,
  "merchant_reference": "",
  "minimum_age": 0,
  "monetary_account_id": 0,
  "redirect_url": "",
  "reference_split_the_bill": [
    "BillingInvoice": [
      "address": [],
      "alias": [],
      "category": "",
      "chamber_of_commerce_number": "",
      "counterparty_address": [],
      "counterparty_alias": [],
      "created": "",
      "description": "",
      "external_url": "",
      "group": [
        [
          "instance_description": "",
          "item": [
            [
              "billing_date": "",
              "id": 0,
              "quantity": 0,
              "total_vat_exclusive": [],
              "total_vat_inclusive": [],
              "type_description": "",
              "type_description_translated": "",
              "unit_vat_exclusive": [],
              "unit_vat_inclusive": [],
              "vat": 0
            ]
          ],
          "product_vat_exclusive": [],
          "product_vat_inclusive": [],
          "type": "",
          "type_description": "",
          "type_description_translated": ""
        ]
      ],
      "id": 0,
      "invoice_date": "",
      "invoice_number": "",
      "request_reference_split_the_bill": [
        [
          "id": 0,
          "type": ""
        ]
      ],
      "status": "",
      "total_vat": [],
      "total_vat_exclusive": [],
      "total_vat_inclusive": [],
      "updated": "",
      "vat_number": ""
    ],
    "DraftPayment": [
      "entries": [
        [
          "alias": [],
          "amount": [],
          "attachment": [
            [
              "id": 0,
              "monetary_account_id": 0
            ]
          ],
          "counterparty_alias": [],
          "description": "",
          "id": 0,
          "merchant_reference": "",
          "type": ""
        ]
      ],
      "number_of_required_accepts": 0,
      "previous_updated_timestamp": "",
      "schedule": [
        "object": [
          "Payment": [
            "address_billing": [],
            "address_shipping": [],
            "alias": [],
            "allow_bunqto": false,
            "amount": [],
            "attachment": [[]],
            "balance_after_mutation": [],
            "batch_id": 0,
            "bunqto_expiry": "",
            "bunqto_share_url": "",
            "bunqto_status": "",
            "bunqto_sub_status": "",
            "bunqto_time_responded": "",
            "counterparty_alias": [],
            "created": "",
            "description": "",
            "geolocation": [],
            "id": 0,
            "merchant_reference": "",
            "monetary_account_id": 0,
            "payment_auto_allocate_instance": [
              "created": "",
              "error_message": [],
              "id": 0,
              "payment_auto_allocate_id": 0,
              "payment_batch": ["payments": ["Payment": []]],
              "payment_id": 0,
              "status": "",
              "updated": ""
            ],
            "request_reference_split_the_bill": [[]],
            "scheduled_id": 0,
            "sub_type": "",
            "type": "",
            "updated": ""
          ],
          "PaymentBatch": []
        ],
        "recurrence_size": 0,
        "recurrence_unit": "",
        "status": "",
        "time_end": "",
        "time_start": ""
      ],
      "status": ""
    ],
    "MasterCardAction": [
      "alias": [],
      "all_mastercard_action_refund": [
        [
          "additional_information": [
            "attachment": [["id": 0]],
            "category": "",
            "comment": "",
            "reason": "",
            "terms_and_conditions": ""
          ],
          "alias": [],
          "amount": [],
          "attachment": [[]],
          "category": "",
          "comment": "",
          "counterparty_alias": [],
          "created": "",
          "description": "",
          "id": 0,
          "label_card": [
            "expiry_date": "",
            "label_user": [],
            "second_line": "",
            "status": "",
            "type": "",
            "uuid": ""
          ],
          "label_user_creator": [],
          "mastercard_action_id": 0,
          "reason": "",
          "reference_mastercard_action_event": [["event_id": 0]],
          "status": "",
          "status_description": "",
          "status_description_translated": "",
          "status_together_url": "",
          "sub_type": "",
          "terms_and_conditions": "",
          "time_refund": "",
          "type": "",
          "updated": ""
        ]
      ],
      "amount_billing": [],
      "amount_converted": [],
      "amount_fee": [],
      "amount_local": [],
      "amount_original_billing": [],
      "amount_original_local": [],
      "applied_limit": "",
      "authorisation_status": "",
      "authorisation_type": "",
      "card_authorisation_id_response": "",
      "card_id": 0,
      "city": "",
      "clearing_expiry_time": "",
      "clearing_status": "",
      "counterparty_alias": [],
      "decision": "",
      "decision_description": "",
      "decision_description_translated": "",
      "decision_together_url": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "id": 0,
      "label_card": [],
      "maturity_date": "",
      "monetary_account_id": 0,
      "pan_entry_mode_user": "",
      "payment_status": "",
      "pos_card_holder_presence": "",
      "pos_card_presence": "",
      "request_reference_split_the_bill": [[]],
      "reservation_expiry_time": "",
      "secure_code_id": 0,
      "settlement_status": "",
      "token_status": "",
      "wallet_provider_id": ""
    ],
    "Payment": [],
    "PaymentBatch": [],
    "RequestResponse": [
      "address_billing": [],
      "address_shipping": [],
      "alias": [],
      "amount_inquired": [],
      "amount_responded": [],
      "attachment": [
        [
          "content_type": "",
          "description": "",
          "urls": [
            [
              "type": "",
              "url": ""
            ]
          ]
        ]
      ],
      "counterparty_alias": [],
      "created": "",
      "credit_scheme_identifier": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "event_id": 0,
      "geolocation": [],
      "id": 0,
      "mandate_identifier": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "request_reference_split_the_bill": [[]],
      "require_address": "",
      "status": "",
      "sub_type": "",
      "time_expiry": "",
      "time_refund_requested": "",
      "time_refunded": "",
      "time_responded": "",
      "type": "",
      "updated": "",
      "user_refund_requested": []
    ],
    "ScheduleInstance": [
      "error_message": [],
      "request_reference_split_the_bill": [[]],
      "result_object": [
        "Payment": [],
        "PaymentBatch": []
      ],
      "scheduled_object": [],
      "state": "",
      "time_end": "",
      "time_start": ""
    ],
    "TransferwisePayment": [
      "alias": [],
      "amount_source": [],
      "amount_target": [],
      "counterparty_alias": [],
      "monetary_account_id": "",
      "pay_in_reference": "",
      "quote": [
        "amount_fee": [],
        "amount_source": [],
        "amount_target": [],
        "created": "",
        "currency_source": "",
        "currency_target": "",
        "id": 0,
        "quote_id": "",
        "rate": "",
        "time_delivery_estimate": "",
        "time_expiry": "",
        "updated": ""
      ],
      "rate": "",
      "recipient_id": "",
      "reference": "",
      "status": "",
      "status_transferwise": "",
      "status_transferwise_issue": "",
      "sub_status": "",
      "time_delivery_estimate": ""
    ],
    "WhitelistResult": [
      "error_message": [],
      "id": 0,
      "monetary_account_paying_id": 0,
      "object": [
        "draftPayment": [],
        "id": 0,
        "requestResponse": []
      ],
      "request_reference_split_the_bill": [[]],
      "status": "",
      "sub_status": "",
      "whitelist": []
    ]
  ],
  "require_address": "",
  "scheduled_id": 0,
  "status": "",
  "time_expiry": "",
  "time_responded": "",
  "updated": "",
  "user_alias_created": [],
  "user_alias_revoked": [],
  "want_tip": false
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_RequestInquiry_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry" {:headers {:user-agent ""
                                                                                                                       :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_RequestInquiry_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId" {:headers {:user-agent ""
                                                                                                                               :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_RequestInquiry_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
itemId
BODY json

{
  "address_billing": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_shipping": {},
  "allow_amount_higher": false,
  "allow_amount_lower": false,
  "allow_bunqme": false,
  "amount_inquired": {
    "currency": "",
    "value": ""
  },
  "amount_responded": {},
  "attachment": [
    {
      "id": 0
    }
  ],
  "batch_id": 0,
  "bunqme_share_url": "",
  "counterparty_alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "created": "",
  "description": "",
  "event_id": 0,
  "geolocation": {
    "altitude": 0,
    "latitude": 0,
    "longitude": 0,
    "radius": 0
  },
  "id": 0,
  "merchant_reference": "",
  "minimum_age": 0,
  "monetary_account_id": 0,
  "redirect_url": "",
  "reference_split_the_bill": {
    "BillingInvoice": {
      "address": {},
      "alias": {},
      "category": "",
      "chamber_of_commerce_number": "",
      "counterparty_address": {},
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "external_url": "",
      "group": [
        {
          "instance_description": "",
          "item": [
            {
              "billing_date": "",
              "id": 0,
              "quantity": 0,
              "total_vat_exclusive": {},
              "total_vat_inclusive": {},
              "type_description": "",
              "type_description_translated": "",
              "unit_vat_exclusive": {},
              "unit_vat_inclusive": {},
              "vat": 0
            }
          ],
          "product_vat_exclusive": {},
          "product_vat_inclusive": {},
          "type": "",
          "type_description": "",
          "type_description_translated": ""
        }
      ],
      "id": 0,
      "invoice_date": "",
      "invoice_number": "",
      "request_reference_split_the_bill": [
        {
          "id": 0,
          "type": ""
        }
      ],
      "status": "",
      "total_vat": {},
      "total_vat_exclusive": {},
      "total_vat_inclusive": {},
      "updated": "",
      "vat_number": ""
    },
    "DraftPayment": {
      "entries": [
        {
          "alias": {},
          "amount": {},
          "attachment": [
            {
              "id": 0,
              "monetary_account_id": 0
            }
          ],
          "counterparty_alias": {},
          "description": "",
          "id": 0,
          "merchant_reference": "",
          "type": ""
        }
      ],
      "number_of_required_accepts": 0,
      "previous_updated_timestamp": "",
      "schedule": {
        "object": {
          "Payment": {
            "address_billing": {},
            "address_shipping": {},
            "alias": {},
            "allow_bunqto": false,
            "amount": {},
            "attachment": [
              {}
            ],
            "balance_after_mutation": {},
            "batch_id": 0,
            "bunqto_expiry": "",
            "bunqto_share_url": "",
            "bunqto_status": "",
            "bunqto_sub_status": "",
            "bunqto_time_responded": "",
            "counterparty_alias": {},
            "created": "",
            "description": "",
            "geolocation": {},
            "id": 0,
            "merchant_reference": "",
            "monetary_account_id": 0,
            "payment_auto_allocate_instance": {
              "created": "",
              "error_message": [],
              "id": 0,
              "payment_auto_allocate_id": 0,
              "payment_batch": {
                "payments": {
                  "Payment": []
                }
              },
              "payment_id": 0,
              "status": "",
              "updated": ""
            },
            "request_reference_split_the_bill": [
              {}
            ],
            "scheduled_id": 0,
            "sub_type": "",
            "type": "",
            "updated": ""
          },
          "PaymentBatch": {}
        },
        "recurrence_size": 0,
        "recurrence_unit": "",
        "status": "",
        "time_end": "",
        "time_start": ""
      },
      "status": ""
    },
    "MasterCardAction": {
      "alias": {},
      "all_mastercard_action_refund": [
        {
          "additional_information": {
            "attachment": [
              {
                "id": 0
              }
            ],
            "category": "",
            "comment": "",
            "reason": "",
            "terms_and_conditions": ""
          },
          "alias": {},
          "amount": {},
          "attachment": [
            {}
          ],
          "category": "",
          "comment": "",
          "counterparty_alias": {},
          "created": "",
          "description": "",
          "id": 0,
          "label_card": {
            "expiry_date": "",
            "label_user": {},
            "second_line": "",
            "status": "",
            "type": "",
            "uuid": ""
          },
          "label_user_creator": {},
          "mastercard_action_id": 0,
          "reason": "",
          "reference_mastercard_action_event": [
            {
              "event_id": 0
            }
          ],
          "status": "",
          "status_description": "",
          "status_description_translated": "",
          "status_together_url": "",
          "sub_type": "",
          "terms_and_conditions": "",
          "time_refund": "",
          "type": "",
          "updated": ""
        }
      ],
      "amount_billing": {},
      "amount_converted": {},
      "amount_fee": {},
      "amount_local": {},
      "amount_original_billing": {},
      "amount_original_local": {},
      "applied_limit": "",
      "authorisation_status": "",
      "authorisation_type": "",
      "card_authorisation_id_response": "",
      "card_id": 0,
      "city": "",
      "clearing_expiry_time": "",
      "clearing_status": "",
      "counterparty_alias": {},
      "decision": "",
      "decision_description": "",
      "decision_description_translated": "",
      "decision_together_url": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "id": 0,
      "label_card": {},
      "maturity_date": "",
      "monetary_account_id": 0,
      "pan_entry_mode_user": "",
      "payment_status": "",
      "pos_card_holder_presence": "",
      "pos_card_presence": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "reservation_expiry_time": "",
      "secure_code_id": 0,
      "settlement_status": "",
      "token_status": "",
      "wallet_provider_id": ""
    },
    "Payment": {},
    "PaymentBatch": {},
    "RequestResponse": {
      "address_billing": {},
      "address_shipping": {},
      "alias": {},
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "content_type": "",
          "description": "",
          "urls": [
            {
              "type": "",
              "url": ""
            }
          ]
        }
      ],
      "counterparty_alias": {},
      "created": "",
      "credit_scheme_identifier": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "mandate_identifier": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "require_address": "",
      "status": "",
      "sub_type": "",
      "time_expiry": "",
      "time_refund_requested": "",
      "time_refunded": "",
      "time_responded": "",
      "type": "",
      "updated": "",
      "user_refund_requested": {}
    },
    "ScheduleInstance": {
      "error_message": [],
      "request_reference_split_the_bill": [
        {}
      ],
      "result_object": {
        "Payment": {},
        "PaymentBatch": {}
      },
      "scheduled_object": {},
      "state": "",
      "time_end": "",
      "time_start": ""
    },
    "TransferwisePayment": {
      "alias": {},
      "amount_source": {},
      "amount_target": {},
      "counterparty_alias": {},
      "monetary_account_id": "",
      "pay_in_reference": "",
      "quote": {
        "amount_fee": {},
        "amount_source": {},
        "amount_target": {},
        "created": "",
        "currency_source": "",
        "currency_target": "",
        "id": 0,
        "quote_id": "",
        "rate": "",
        "time_delivery_estimate": "",
        "time_expiry": "",
        "updated": ""
      },
      "rate": "",
      "recipient_id": "",
      "reference": "",
      "status": "",
      "status_transferwise": "",
      "status_transferwise_issue": "",
      "sub_status": "",
      "time_delivery_estimate": ""
    },
    "WhitelistResult": {
      "error_message": [],
      "id": 0,
      "monetary_account_paying_id": 0,
      "object": {
        "draftPayment": {},
        "id": 0,
        "requestResponse": {}
      },
      "request_reference_split_the_bill": [
        {}
      ],
      "status": "",
      "sub_status": "",
      "whitelist": {}
    }
  },
  "require_address": "",
  "scheduled_id": 0,
  "status": "",
  "time_expiry": "",
  "time_responded": "",
  "updated": "",
  "user_alias_created": {},
  "user_alias_revoked": {},
  "want_tip": false
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"allow_amount_higher\": false,\n  \"allow_amount_lower\": false,\n  \"allow_bunqme\": false,\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"id\": 0\n    }\n  ],\n  \"batch_id\": 0,\n  \"bunqme_share_url\": \"\",\n  \"counterparty_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {},\n      \"alias\": {},\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {},\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {},\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"require_address\": \"\",\n  \"scheduled_id\": 0,\n  \"status\": \"\",\n  \"time_expiry\": \"\",\n  \"time_responded\": \"\",\n  \"updated\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {},\n  \"want_tip\": false\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId" {:headers {:user-agent ""
                                                                                                                               :x-bunq-client-authentication ""}
                                                                                                                     :content-type :json
                                                                                                                     :form-params {:address_billing {:city ""
                                                                                                                                                     :country ""
                                                                                                                                                     :extra ""
                                                                                                                                                     :house_number ""
                                                                                                                                                     :is_user_address_updated false
                                                                                                                                                     :mailbox_name ""
                                                                                                                                                     :po_box ""
                                                                                                                                                     :postal_code ""
                                                                                                                                                     :province ""
                                                                                                                                                     :street ""}
                                                                                                                                   :address_shipping {}
                                                                                                                                   :allow_amount_higher false
                                                                                                                                   :allow_amount_lower false
                                                                                                                                   :allow_bunqme false
                                                                                                                                   :amount_inquired {:currency ""
                                                                                                                                                     :value ""}
                                                                                                                                   :amount_responded {}
                                                                                                                                   :attachment [{:id 0}]
                                                                                                                                   :batch_id 0
                                                                                                                                   :bunqme_share_url ""
                                                                                                                                   :counterparty_alias {:avatar {:anchor_uuid ""
                                                                                                                                                                 :image [{:attachment_public_uuid ""
                                                                                                                                                                          :content_type ""
                                                                                                                                                                          :height 0
                                                                                                                                                                          :width 0}]
                                                                                                                                                                 :style ""
                                                                                                                                                                 :uuid ""}
                                                                                                                                                        :bunq_me {:name ""
                                                                                                                                                                  :service ""
                                                                                                                                                                  :type ""
                                                                                                                                                                  :value ""}
                                                                                                                                                        :country ""
                                                                                                                                                        :display_name ""
                                                                                                                                                        :iban ""
                                                                                                                                                        :is_light false
                                                                                                                                                        :label_user {:avatar {}
                                                                                                                                                                     :country ""
                                                                                                                                                                     :display_name ""
                                                                                                                                                                     :public_nick_name ""
                                                                                                                                                                     :uuid ""}
                                                                                                                                                        :merchant_category_code ""
                                                                                                                                                        :swift_account_number ""
                                                                                                                                                        :swift_bic ""
                                                                                                                                                        :transferwise_account_number ""
                                                                                                                                                        :transferwise_bank_code ""}
                                                                                                                                   :created ""
                                                                                                                                   :description ""
                                                                                                                                   :event_id 0
                                                                                                                                   :geolocation {:altitude 0
                                                                                                                                                 :latitude 0
                                                                                                                                                 :longitude 0
                                                                                                                                                 :radius 0}
                                                                                                                                   :id 0
                                                                                                                                   :merchant_reference ""
                                                                                                                                   :minimum_age 0
                                                                                                                                   :monetary_account_id 0
                                                                                                                                   :redirect_url ""
                                                                                                                                   :reference_split_the_bill {:BillingInvoice {:address {}
                                                                                                                                                                               :alias {}
                                                                                                                                                                               :category ""
                                                                                                                                                                               :chamber_of_commerce_number ""
                                                                                                                                                                               :counterparty_address {}
                                                                                                                                                                               :counterparty_alias {}
                                                                                                                                                                               :created ""
                                                                                                                                                                               :description ""
                                                                                                                                                                               :external_url ""
                                                                                                                                                                               :group [{:instance_description ""
                                                                                                                                                                                        :item [{:billing_date ""
                                                                                                                                                                                                :id 0
                                                                                                                                                                                                :quantity 0
                                                                                                                                                                                                :total_vat_exclusive {}
                                                                                                                                                                                                :total_vat_inclusive {}
                                                                                                                                                                                                :type_description ""
                                                                                                                                                                                                :type_description_translated ""
                                                                                                                                                                                                :unit_vat_exclusive {}
                                                                                                                                                                                                :unit_vat_inclusive {}
                                                                                                                                                                                                :vat 0}]
                                                                                                                                                                                        :product_vat_exclusive {}
                                                                                                                                                                                        :product_vat_inclusive {}
                                                                                                                                                                                        :type ""
                                                                                                                                                                                        :type_description ""
                                                                                                                                                                                        :type_description_translated ""}]
                                                                                                                                                                               :id 0
                                                                                                                                                                               :invoice_date ""
                                                                                                                                                                               :invoice_number ""
                                                                                                                                                                               :request_reference_split_the_bill [{:id 0
                                                                                                                                                                                                                   :type ""}]
                                                                                                                                                                               :status ""
                                                                                                                                                                               :total_vat {}
                                                                                                                                                                               :total_vat_exclusive {}
                                                                                                                                                                               :total_vat_inclusive {}
                                                                                                                                                                               :updated ""
                                                                                                                                                                               :vat_number ""}
                                                                                                                                                              :DraftPayment {:entries [{:alias {}
                                                                                                                                                                                        :amount {}
                                                                                                                                                                                        :attachment [{:id 0
                                                                                                                                                                                                      :monetary_account_id 0}]
                                                                                                                                                                                        :counterparty_alias {}
                                                                                                                                                                                        :description ""
                                                                                                                                                                                        :id 0
                                                                                                                                                                                        :merchant_reference ""
                                                                                                                                                                                        :type ""}]
                                                                                                                                                                             :number_of_required_accepts 0
                                                                                                                                                                             :previous_updated_timestamp ""
                                                                                                                                                                             :schedule {:object {:Payment {:address_billing {}
                                                                                                                                                                                                           :address_shipping {}
                                                                                                                                                                                                           :alias {}
                                                                                                                                                                                                           :allow_bunqto false
                                                                                                                                                                                                           :amount {}
                                                                                                                                                                                                           :attachment [{}]
                                                                                                                                                                                                           :balance_after_mutation {}
                                                                                                                                                                                                           :batch_id 0
                                                                                                                                                                                                           :bunqto_expiry ""
                                                                                                                                                                                                           :bunqto_share_url ""
                                                                                                                                                                                                           :bunqto_status ""
                                                                                                                                                                                                           :bunqto_sub_status ""
                                                                                                                                                                                                           :bunqto_time_responded ""
                                                                                                                                                                                                           :counterparty_alias {}
                                                                                                                                                                                                           :created ""
                                                                                                                                                                                                           :description ""
                                                                                                                                                                                                           :geolocation {}
                                                                                                                                                                                                           :id 0
                                                                                                                                                                                                           :merchant_reference ""
                                                                                                                                                                                                           :monetary_account_id 0
                                                                                                                                                                                                           :payment_auto_allocate_instance {:created ""
                                                                                                                                                                                                                                            :error_message []
                                                                                                                                                                                                                                            :id 0
                                                                                                                                                                                                                                            :payment_auto_allocate_id 0
                                                                                                                                                                                                                                            :payment_batch {:payments {:Payment []}}
                                                                                                                                                                                                                                            :payment_id 0
                                                                                                                                                                                                                                            :status ""
                                                                                                                                                                                                                                            :updated ""}
                                                                                                                                                                                                           :request_reference_split_the_bill [{}]
                                                                                                                                                                                                           :scheduled_id 0
                                                                                                                                                                                                           :sub_type ""
                                                                                                                                                                                                           :type ""
                                                                                                                                                                                                           :updated ""}
                                                                                                                                                                                                 :PaymentBatch {}}
                                                                                                                                                                                        :recurrence_size 0
                                                                                                                                                                                        :recurrence_unit ""
                                                                                                                                                                                        :status ""
                                                                                                                                                                                        :time_end ""
                                                                                                                                                                                        :time_start ""}
                                                                                                                                                                             :status ""}
                                                                                                                                                              :MasterCardAction {:alias {}
                                                                                                                                                                                 :all_mastercard_action_refund [{:additional_information {:attachment [{:id 0}]
                                                                                                                                                                                                                                          :category ""
                                                                                                                                                                                                                                          :comment ""
                                                                                                                                                                                                                                          :reason ""
                                                                                                                                                                                                                                          :terms_and_conditions ""}
                                                                                                                                                                                                                 :alias {}
                                                                                                                                                                                                                 :amount {}
                                                                                                                                                                                                                 :attachment [{}]
                                                                                                                                                                                                                 :category ""
                                                                                                                                                                                                                 :comment ""
                                                                                                                                                                                                                 :counterparty_alias {}
                                                                                                                                                                                                                 :created ""
                                                                                                                                                                                                                 :description ""
                                                                                                                                                                                                                 :id 0
                                                                                                                                                                                                                 :label_card {:expiry_date ""
                                                                                                                                                                                                                              :label_user {}
                                                                                                                                                                                                                              :second_line ""
                                                                                                                                                                                                                              :status ""
                                                                                                                                                                                                                              :type ""
                                                                                                                                                                                                                              :uuid ""}
                                                                                                                                                                                                                 :label_user_creator {}
                                                                                                                                                                                                                 :mastercard_action_id 0
                                                                                                                                                                                                                 :reason ""
                                                                                                                                                                                                                 :reference_mastercard_action_event [{:event_id 0}]
                                                                                                                                                                                                                 :status ""
                                                                                                                                                                                                                 :status_description ""
                                                                                                                                                                                                                 :status_description_translated ""
                                                                                                                                                                                                                 :status_together_url ""
                                                                                                                                                                                                                 :sub_type ""
                                                                                                                                                                                                                 :terms_and_conditions ""
                                                                                                                                                                                                                 :time_refund ""
                                                                                                                                                                                                                 :type ""
                                                                                                                                                                                                                 :updated ""}]
                                                                                                                                                                                 :amount_billing {}
                                                                                                                                                                                 :amount_converted {}
                                                                                                                                                                                 :amount_fee {}
                                                                                                                                                                                 :amount_local {}
                                                                                                                                                                                 :amount_original_billing {}
                                                                                                                                                                                 :amount_original_local {}
                                                                                                                                                                                 :applied_limit ""
                                                                                                                                                                                 :authorisation_status ""
                                                                                                                                                                                 :authorisation_type ""
                                                                                                                                                                                 :card_authorisation_id_response ""
                                                                                                                                                                                 :card_id 0
                                                                                                                                                                                 :city ""
                                                                                                                                                                                 :clearing_expiry_time ""
                                                                                                                                                                                 :clearing_status ""
                                                                                                                                                                                 :counterparty_alias {}
                                                                                                                                                                                 :decision ""
                                                                                                                                                                                 :decision_description ""
                                                                                                                                                                                 :decision_description_translated ""
                                                                                                                                                                                 :decision_together_url ""
                                                                                                                                                                                 :description ""
                                                                                                                                                                                 :eligible_whitelist_id 0
                                                                                                                                                                                 :id 0
                                                                                                                                                                                 :label_card {}
                                                                                                                                                                                 :maturity_date ""
                                                                                                                                                                                 :monetary_account_id 0
                                                                                                                                                                                 :pan_entry_mode_user ""
                                                                                                                                                                                 :payment_status ""
                                                                                                                                                                                 :pos_card_holder_presence ""
                                                                                                                                                                                 :pos_card_presence ""
                                                                                                                                                                                 :request_reference_split_the_bill [{}]
                                                                                                                                                                                 :reservation_expiry_time ""
                                                                                                                                                                                 :secure_code_id 0
                                                                                                                                                                                 :settlement_status ""
                                                                                                                                                                                 :token_status ""
                                                                                                                                                                                 :wallet_provider_id ""}
                                                                                                                                                              :Payment {}
                                                                                                                                                              :PaymentBatch {}
                                                                                                                                                              :RequestResponse {:address_billing {}
                                                                                                                                                                                :address_shipping {}
                                                                                                                                                                                :alias {}
                                                                                                                                                                                :amount_inquired {}
                                                                                                                                                                                :amount_responded {}
                                                                                                                                                                                :attachment [{:content_type ""
                                                                                                                                                                                              :description ""
                                                                                                                                                                                              :urls [{:type ""
                                                                                                                                                                                                      :url ""}]}]
                                                                                                                                                                                :counterparty_alias {}
                                                                                                                                                                                :created ""
                                                                                                                                                                                :credit_scheme_identifier ""
                                                                                                                                                                                :description ""
                                                                                                                                                                                :eligible_whitelist_id 0
                                                                                                                                                                                :event_id 0
                                                                                                                                                                                :geolocation {}
                                                                                                                                                                                :id 0
                                                                                                                                                                                :mandate_identifier ""
                                                                                                                                                                                :minimum_age 0
                                                                                                                                                                                :monetary_account_id 0
                                                                                                                                                                                :redirect_url ""
                                                                                                                                                                                :request_reference_split_the_bill [{}]
                                                                                                                                                                                :require_address ""
                                                                                                                                                                                :status ""
                                                                                                                                                                                :sub_type ""
                                                                                                                                                                                :time_expiry ""
                                                                                                                                                                                :time_refund_requested ""
                                                                                                                                                                                :time_refunded ""
                                                                                                                                                                                :time_responded ""
                                                                                                                                                                                :type ""
                                                                                                                                                                                :updated ""
                                                                                                                                                                                :user_refund_requested {}}
                                                                                                                                                              :ScheduleInstance {:error_message []
                                                                                                                                                                                 :request_reference_split_the_bill [{}]
                                                                                                                                                                                 :result_object {:Payment {}
                                                                                                                                                                                                 :PaymentBatch {}}
                                                                                                                                                                                 :scheduled_object {}
                                                                                                                                                                                 :state ""
                                                                                                                                                                                 :time_end ""
                                                                                                                                                                                 :time_start ""}
                                                                                                                                                              :TransferwisePayment {:alias {}
                                                                                                                                                                                    :amount_source {}
                                                                                                                                                                                    :amount_target {}
                                                                                                                                                                                    :counterparty_alias {}
                                                                                                                                                                                    :monetary_account_id ""
                                                                                                                                                                                    :pay_in_reference ""
                                                                                                                                                                                    :quote {:amount_fee {}
                                                                                                                                                                                            :amount_source {}
                                                                                                                                                                                            :amount_target {}
                                                                                                                                                                                            :created ""
                                                                                                                                                                                            :currency_source ""
                                                                                                                                                                                            :currency_target ""
                                                                                                                                                                                            :id 0
                                                                                                                                                                                            :quote_id ""
                                                                                                                                                                                            :rate ""
                                                                                                                                                                                            :time_delivery_estimate ""
                                                                                                                                                                                            :time_expiry ""
                                                                                                                                                                                            :updated ""}
                                                                                                                                                                                    :rate ""
                                                                                                                                                                                    :recipient_id ""
                                                                                                                                                                                    :reference ""
                                                                                                                                                                                    :status ""
                                                                                                                                                                                    :status_transferwise ""
                                                                                                                                                                                    :status_transferwise_issue ""
                                                                                                                                                                                    :sub_status ""
                                                                                                                                                                                    :time_delivery_estimate ""}
                                                                                                                                                              :WhitelistResult {:error_message []
                                                                                                                                                                                :id 0
                                                                                                                                                                                :monetary_account_paying_id 0
                                                                                                                                                                                :object {:draftPayment {}
                                                                                                                                                                                         :id 0
                                                                                                                                                                                         :requestResponse {}}
                                                                                                                                                                                :request_reference_split_the_bill [{}]
                                                                                                                                                                                :status ""
                                                                                                                                                                                :sub_status ""
                                                                                                                                                                                :whitelist {}}}
                                                                                                                                   :require_address ""
                                                                                                                                   :scheduled_id 0
                                                                                                                                   :status ""
                                                                                                                                   :time_expiry ""
                                                                                                                                   :time_responded ""
                                                                                                                                   :updated ""
                                                                                                                                   :user_alias_created {}
                                                                                                                                   :user_alias_revoked {}
                                                                                                                                   :want_tip false}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"allow_amount_higher\": false,\n  \"allow_amount_lower\": false,\n  \"allow_bunqme\": false,\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"id\": 0\n    }\n  ],\n  \"batch_id\": 0,\n  \"bunqme_share_url\": \"\",\n  \"counterparty_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {},\n      \"alias\": {},\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {},\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {},\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"require_address\": \"\",\n  \"scheduled_id\": 0,\n  \"status\": \"\",\n  \"time_expiry\": \"\",\n  \"time_responded\": \"\",\n  \"updated\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {},\n  \"want_tip\": false\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"allow_amount_higher\": false,\n  \"allow_amount_lower\": false,\n  \"allow_bunqme\": false,\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"id\": 0\n    }\n  ],\n  \"batch_id\": 0,\n  \"bunqme_share_url\": \"\",\n  \"counterparty_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {},\n      \"alias\": {},\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {},\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {},\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"require_address\": \"\",\n  \"scheduled_id\": 0,\n  \"status\": \"\",\n  \"time_expiry\": \"\",\n  \"time_responded\": \"\",\n  \"updated\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {},\n  \"want_tip\": false\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"allow_amount_higher\": false,\n  \"allow_amount_lower\": false,\n  \"allow_bunqme\": false,\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"id\": 0\n    }\n  ],\n  \"batch_id\": 0,\n  \"bunqme_share_url\": \"\",\n  \"counterparty_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {},\n      \"alias\": {},\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {},\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {},\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"require_address\": \"\",\n  \"scheduled_id\": 0,\n  \"status\": \"\",\n  \"time_expiry\": \"\",\n  \"time_responded\": \"\",\n  \"updated\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {},\n  \"want_tip\": false\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId"

	payload := strings.NewReader("{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"allow_amount_higher\": false,\n  \"allow_amount_lower\": false,\n  \"allow_bunqme\": false,\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"id\": 0\n    }\n  ],\n  \"batch_id\": 0,\n  \"bunqme_share_url\": \"\",\n  \"counterparty_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {},\n      \"alias\": {},\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {},\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {},\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"require_address\": \"\",\n  \"scheduled_id\": 0,\n  \"status\": \"\",\n  \"time_expiry\": \"\",\n  \"time_responded\": \"\",\n  \"updated\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {},\n  \"want_tip\": false\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 10061

{
  "address_billing": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_shipping": {},
  "allow_amount_higher": false,
  "allow_amount_lower": false,
  "allow_bunqme": false,
  "amount_inquired": {
    "currency": "",
    "value": ""
  },
  "amount_responded": {},
  "attachment": [
    {
      "id": 0
    }
  ],
  "batch_id": 0,
  "bunqme_share_url": "",
  "counterparty_alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "created": "",
  "description": "",
  "event_id": 0,
  "geolocation": {
    "altitude": 0,
    "latitude": 0,
    "longitude": 0,
    "radius": 0
  },
  "id": 0,
  "merchant_reference": "",
  "minimum_age": 0,
  "monetary_account_id": 0,
  "redirect_url": "",
  "reference_split_the_bill": {
    "BillingInvoice": {
      "address": {},
      "alias": {},
      "category": "",
      "chamber_of_commerce_number": "",
      "counterparty_address": {},
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "external_url": "",
      "group": [
        {
          "instance_description": "",
          "item": [
            {
              "billing_date": "",
              "id": 0,
              "quantity": 0,
              "total_vat_exclusive": {},
              "total_vat_inclusive": {},
              "type_description": "",
              "type_description_translated": "",
              "unit_vat_exclusive": {},
              "unit_vat_inclusive": {},
              "vat": 0
            }
          ],
          "product_vat_exclusive": {},
          "product_vat_inclusive": {},
          "type": "",
          "type_description": "",
          "type_description_translated": ""
        }
      ],
      "id": 0,
      "invoice_date": "",
      "invoice_number": "",
      "request_reference_split_the_bill": [
        {
          "id": 0,
          "type": ""
        }
      ],
      "status": "",
      "total_vat": {},
      "total_vat_exclusive": {},
      "total_vat_inclusive": {},
      "updated": "",
      "vat_number": ""
    },
    "DraftPayment": {
      "entries": [
        {
          "alias": {},
          "amount": {},
          "attachment": [
            {
              "id": 0,
              "monetary_account_id": 0
            }
          ],
          "counterparty_alias": {},
          "description": "",
          "id": 0,
          "merchant_reference": "",
          "type": ""
        }
      ],
      "number_of_required_accepts": 0,
      "previous_updated_timestamp": "",
      "schedule": {
        "object": {
          "Payment": {
            "address_billing": {},
            "address_shipping": {},
            "alias": {},
            "allow_bunqto": false,
            "amount": {},
            "attachment": [
              {}
            ],
            "balance_after_mutation": {},
            "batch_id": 0,
            "bunqto_expiry": "",
            "bunqto_share_url": "",
            "bunqto_status": "",
            "bunqto_sub_status": "",
            "bunqto_time_responded": "",
            "counterparty_alias": {},
            "created": "",
            "description": "",
            "geolocation": {},
            "id": 0,
            "merchant_reference": "",
            "monetary_account_id": 0,
            "payment_auto_allocate_instance": {
              "created": "",
              "error_message": [],
              "id": 0,
              "payment_auto_allocate_id": 0,
              "payment_batch": {
                "payments": {
                  "Payment": []
                }
              },
              "payment_id": 0,
              "status": "",
              "updated": ""
            },
            "request_reference_split_the_bill": [
              {}
            ],
            "scheduled_id": 0,
            "sub_type": "",
            "type": "",
            "updated": ""
          },
          "PaymentBatch": {}
        },
        "recurrence_size": 0,
        "recurrence_unit": "",
        "status": "",
        "time_end": "",
        "time_start": ""
      },
      "status": ""
    },
    "MasterCardAction": {
      "alias": {},
      "all_mastercard_action_refund": [
        {
          "additional_information": {
            "attachment": [
              {
                "id": 0
              }
            ],
            "category": "",
            "comment": "",
            "reason": "",
            "terms_and_conditions": ""
          },
          "alias": {},
          "amount": {},
          "attachment": [
            {}
          ],
          "category": "",
          "comment": "",
          "counterparty_alias": {},
          "created": "",
          "description": "",
          "id": 0,
          "label_card": {
            "expiry_date": "",
            "label_user": {},
            "second_line": "",
            "status": "",
            "type": "",
            "uuid": ""
          },
          "label_user_creator": {},
          "mastercard_action_id": 0,
          "reason": "",
          "reference_mastercard_action_event": [
            {
              "event_id": 0
            }
          ],
          "status": "",
          "status_description": "",
          "status_description_translated": "",
          "status_together_url": "",
          "sub_type": "",
          "terms_and_conditions": "",
          "time_refund": "",
          "type": "",
          "updated": ""
        }
      ],
      "amount_billing": {},
      "amount_converted": {},
      "amount_fee": {},
      "amount_local": {},
      "amount_original_billing": {},
      "amount_original_local": {},
      "applied_limit": "",
      "authorisation_status": "",
      "authorisation_type": "",
      "card_authorisation_id_response": "",
      "card_id": 0,
      "city": "",
      "clearing_expiry_time": "",
      "clearing_status": "",
      "counterparty_alias": {},
      "decision": "",
      "decision_description": "",
      "decision_description_translated": "",
      "decision_together_url": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "id": 0,
      "label_card": {},
      "maturity_date": "",
      "monetary_account_id": 0,
      "pan_entry_mode_user": "",
      "payment_status": "",
      "pos_card_holder_presence": "",
      "pos_card_presence": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "reservation_expiry_time": "",
      "secure_code_id": 0,
      "settlement_status": "",
      "token_status": "",
      "wallet_provider_id": ""
    },
    "Payment": {},
    "PaymentBatch": {},
    "RequestResponse": {
      "address_billing": {},
      "address_shipping": {},
      "alias": {},
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "content_type": "",
          "description": "",
          "urls": [
            {
              "type": "",
              "url": ""
            }
          ]
        }
      ],
      "counterparty_alias": {},
      "created": "",
      "credit_scheme_identifier": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "mandate_identifier": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "require_address": "",
      "status": "",
      "sub_type": "",
      "time_expiry": "",
      "time_refund_requested": "",
      "time_refunded": "",
      "time_responded": "",
      "type": "",
      "updated": "",
      "user_refund_requested": {}
    },
    "ScheduleInstance": {
      "error_message": [],
      "request_reference_split_the_bill": [
        {}
      ],
      "result_object": {
        "Payment": {},
        "PaymentBatch": {}
      },
      "scheduled_object": {},
      "state": "",
      "time_end": "",
      "time_start": ""
    },
    "TransferwisePayment": {
      "alias": {},
      "amount_source": {},
      "amount_target": {},
      "counterparty_alias": {},
      "monetary_account_id": "",
      "pay_in_reference": "",
      "quote": {
        "amount_fee": {},
        "amount_source": {},
        "amount_target": {},
        "created": "",
        "currency_source": "",
        "currency_target": "",
        "id": 0,
        "quote_id": "",
        "rate": "",
        "time_delivery_estimate": "",
        "time_expiry": "",
        "updated": ""
      },
      "rate": "",
      "recipient_id": "",
      "reference": "",
      "status": "",
      "status_transferwise": "",
      "status_transferwise_issue": "",
      "sub_status": "",
      "time_delivery_estimate": ""
    },
    "WhitelistResult": {
      "error_message": [],
      "id": 0,
      "monetary_account_paying_id": 0,
      "object": {
        "draftPayment": {},
        "id": 0,
        "requestResponse": {}
      },
      "request_reference_split_the_bill": [
        {}
      ],
      "status": "",
      "sub_status": "",
      "whitelist": {}
    }
  },
  "require_address": "",
  "scheduled_id": 0,
  "status": "",
  "time_expiry": "",
  "time_responded": "",
  "updated": "",
  "user_alias_created": {},
  "user_alias_revoked": {},
  "want_tip": false
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"allow_amount_higher\": false,\n  \"allow_amount_lower\": false,\n  \"allow_bunqme\": false,\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"id\": 0\n    }\n  ],\n  \"batch_id\": 0,\n  \"bunqme_share_url\": \"\",\n  \"counterparty_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {},\n      \"alias\": {},\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {},\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {},\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"require_address\": \"\",\n  \"scheduled_id\": 0,\n  \"status\": \"\",\n  \"time_expiry\": \"\",\n  \"time_responded\": \"\",\n  \"updated\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {},\n  \"want_tip\": false\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"allow_amount_higher\": false,\n  \"allow_amount_lower\": false,\n  \"allow_bunqme\": false,\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"id\": 0\n    }\n  ],\n  \"batch_id\": 0,\n  \"bunqme_share_url\": \"\",\n  \"counterparty_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {},\n      \"alias\": {},\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {},\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {},\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"require_address\": \"\",\n  \"scheduled_id\": 0,\n  \"status\": \"\",\n  \"time_expiry\": \"\",\n  \"time_responded\": \"\",\n  \"updated\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {},\n  \"want_tip\": false\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"allow_amount_higher\": false,\n  \"allow_amount_lower\": false,\n  \"allow_bunqme\": false,\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"id\": 0\n    }\n  ],\n  \"batch_id\": 0,\n  \"bunqme_share_url\": \"\",\n  \"counterparty_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {},\n      \"alias\": {},\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {},\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {},\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"require_address\": \"\",\n  \"scheduled_id\": 0,\n  \"status\": \"\",\n  \"time_expiry\": \"\",\n  \"time_responded\": \"\",\n  \"updated\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {},\n  \"want_tip\": false\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"allow_amount_higher\": false,\n  \"allow_amount_lower\": false,\n  \"allow_bunqme\": false,\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"id\": 0\n    }\n  ],\n  \"batch_id\": 0,\n  \"bunqme_share_url\": \"\",\n  \"counterparty_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {},\n      \"alias\": {},\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {},\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {},\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"require_address\": \"\",\n  \"scheduled_id\": 0,\n  \"status\": \"\",\n  \"time_expiry\": \"\",\n  \"time_responded\": \"\",\n  \"updated\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {},\n  \"want_tip\": false\n}")
  .asString();
const data = JSON.stringify({
  address_billing: {
    city: '',
    country: '',
    extra: '',
    house_number: '',
    is_user_address_updated: false,
    mailbox_name: '',
    po_box: '',
    postal_code: '',
    province: '',
    street: ''
  },
  address_shipping: {},
  allow_amount_higher: false,
  allow_amount_lower: false,
  allow_bunqme: false,
  amount_inquired: {
    currency: '',
    value: ''
  },
  amount_responded: {},
  attachment: [
    {
      id: 0
    }
  ],
  batch_id: 0,
  bunqme_share_url: '',
  counterparty_alias: {
    avatar: {
      anchor_uuid: '',
      image: [
        {
          attachment_public_uuid: '',
          content_type: '',
          height: 0,
          width: 0
        }
      ],
      style: '',
      uuid: ''
    },
    bunq_me: {
      name: '',
      service: '',
      type: '',
      value: ''
    },
    country: '',
    display_name: '',
    iban: '',
    is_light: false,
    label_user: {
      avatar: {},
      country: '',
      display_name: '',
      public_nick_name: '',
      uuid: ''
    },
    merchant_category_code: '',
    swift_account_number: '',
    swift_bic: '',
    transferwise_account_number: '',
    transferwise_bank_code: ''
  },
  created: '',
  description: '',
  event_id: 0,
  geolocation: {
    altitude: 0,
    latitude: 0,
    longitude: 0,
    radius: 0
  },
  id: 0,
  merchant_reference: '',
  minimum_age: 0,
  monetary_account_id: 0,
  redirect_url: '',
  reference_split_the_bill: {
    BillingInvoice: {
      address: {},
      alias: {},
      category: '',
      chamber_of_commerce_number: '',
      counterparty_address: {},
      counterparty_alias: {},
      created: '',
      description: '',
      external_url: '',
      group: [
        {
          instance_description: '',
          item: [
            {
              billing_date: '',
              id: 0,
              quantity: 0,
              total_vat_exclusive: {},
              total_vat_inclusive: {},
              type_description: '',
              type_description_translated: '',
              unit_vat_exclusive: {},
              unit_vat_inclusive: {},
              vat: 0
            }
          ],
          product_vat_exclusive: {},
          product_vat_inclusive: {},
          type: '',
          type_description: '',
          type_description_translated: ''
        }
      ],
      id: 0,
      invoice_date: '',
      invoice_number: '',
      request_reference_split_the_bill: [
        {
          id: 0,
          type: ''
        }
      ],
      status: '',
      total_vat: {},
      total_vat_exclusive: {},
      total_vat_inclusive: {},
      updated: '',
      vat_number: ''
    },
    DraftPayment: {
      entries: [
        {
          alias: {},
          amount: {},
          attachment: [
            {
              id: 0,
              monetary_account_id: 0
            }
          ],
          counterparty_alias: {},
          description: '',
          id: 0,
          merchant_reference: '',
          type: ''
        }
      ],
      number_of_required_accepts: 0,
      previous_updated_timestamp: '',
      schedule: {
        object: {
          Payment: {
            address_billing: {},
            address_shipping: {},
            alias: {},
            allow_bunqto: false,
            amount: {},
            attachment: [
              {}
            ],
            balance_after_mutation: {},
            batch_id: 0,
            bunqto_expiry: '',
            bunqto_share_url: '',
            bunqto_status: '',
            bunqto_sub_status: '',
            bunqto_time_responded: '',
            counterparty_alias: {},
            created: '',
            description: '',
            geolocation: {},
            id: 0,
            merchant_reference: '',
            monetary_account_id: 0,
            payment_auto_allocate_instance: {
              created: '',
              error_message: [],
              id: 0,
              payment_auto_allocate_id: 0,
              payment_batch: {
                payments: {
                  Payment: []
                }
              },
              payment_id: 0,
              status: '',
              updated: ''
            },
            request_reference_split_the_bill: [
              {}
            ],
            scheduled_id: 0,
            sub_type: '',
            type: '',
            updated: ''
          },
          PaymentBatch: {}
        },
        recurrence_size: 0,
        recurrence_unit: '',
        status: '',
        time_end: '',
        time_start: ''
      },
      status: ''
    },
    MasterCardAction: {
      alias: {},
      all_mastercard_action_refund: [
        {
          additional_information: {
            attachment: [
              {
                id: 0
              }
            ],
            category: '',
            comment: '',
            reason: '',
            terms_and_conditions: ''
          },
          alias: {},
          amount: {},
          attachment: [
            {}
          ],
          category: '',
          comment: '',
          counterparty_alias: {},
          created: '',
          description: '',
          id: 0,
          label_card: {
            expiry_date: '',
            label_user: {},
            second_line: '',
            status: '',
            type: '',
            uuid: ''
          },
          label_user_creator: {},
          mastercard_action_id: 0,
          reason: '',
          reference_mastercard_action_event: [
            {
              event_id: 0
            }
          ],
          status: '',
          status_description: '',
          status_description_translated: '',
          status_together_url: '',
          sub_type: '',
          terms_and_conditions: '',
          time_refund: '',
          type: '',
          updated: ''
        }
      ],
      amount_billing: {},
      amount_converted: {},
      amount_fee: {},
      amount_local: {},
      amount_original_billing: {},
      amount_original_local: {},
      applied_limit: '',
      authorisation_status: '',
      authorisation_type: '',
      card_authorisation_id_response: '',
      card_id: 0,
      city: '',
      clearing_expiry_time: '',
      clearing_status: '',
      counterparty_alias: {},
      decision: '',
      decision_description: '',
      decision_description_translated: '',
      decision_together_url: '',
      description: '',
      eligible_whitelist_id: 0,
      id: 0,
      label_card: {},
      maturity_date: '',
      monetary_account_id: 0,
      pan_entry_mode_user: '',
      payment_status: '',
      pos_card_holder_presence: '',
      pos_card_presence: '',
      request_reference_split_the_bill: [
        {}
      ],
      reservation_expiry_time: '',
      secure_code_id: 0,
      settlement_status: '',
      token_status: '',
      wallet_provider_id: ''
    },
    Payment: {},
    PaymentBatch: {},
    RequestResponse: {
      address_billing: {},
      address_shipping: {},
      alias: {},
      amount_inquired: {},
      amount_responded: {},
      attachment: [
        {
          content_type: '',
          description: '',
          urls: [
            {
              type: '',
              url: ''
            }
          ]
        }
      ],
      counterparty_alias: {},
      created: '',
      credit_scheme_identifier: '',
      description: '',
      eligible_whitelist_id: 0,
      event_id: 0,
      geolocation: {},
      id: 0,
      mandate_identifier: '',
      minimum_age: 0,
      monetary_account_id: 0,
      redirect_url: '',
      request_reference_split_the_bill: [
        {}
      ],
      require_address: '',
      status: '',
      sub_type: '',
      time_expiry: '',
      time_refund_requested: '',
      time_refunded: '',
      time_responded: '',
      type: '',
      updated: '',
      user_refund_requested: {}
    },
    ScheduleInstance: {
      error_message: [],
      request_reference_split_the_bill: [
        {}
      ],
      result_object: {
        Payment: {},
        PaymentBatch: {}
      },
      scheduled_object: {},
      state: '',
      time_end: '',
      time_start: ''
    },
    TransferwisePayment: {
      alias: {},
      amount_source: {},
      amount_target: {},
      counterparty_alias: {},
      monetary_account_id: '',
      pay_in_reference: '',
      quote: {
        amount_fee: {},
        amount_source: {},
        amount_target: {},
        created: '',
        currency_source: '',
        currency_target: '',
        id: 0,
        quote_id: '',
        rate: '',
        time_delivery_estimate: '',
        time_expiry: '',
        updated: ''
      },
      rate: '',
      recipient_id: '',
      reference: '',
      status: '',
      status_transferwise: '',
      status_transferwise_issue: '',
      sub_status: '',
      time_delivery_estimate: ''
    },
    WhitelistResult: {
      error_message: [],
      id: 0,
      monetary_account_paying_id: 0,
      object: {
        draftPayment: {},
        id: 0,
        requestResponse: {}
      },
      request_reference_split_the_bill: [
        {}
      ],
      status: '',
      sub_status: '',
      whitelist: {}
    }
  },
  require_address: '',
  scheduled_id: 0,
  status: '',
  time_expiry: '',
  time_responded: '',
  updated: '',
  user_alias_created: {},
  user_alias_revoked: {},
  want_tip: false
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    address_billing: {
      city: '',
      country: '',
      extra: '',
      house_number: '',
      is_user_address_updated: false,
      mailbox_name: '',
      po_box: '',
      postal_code: '',
      province: '',
      street: ''
    },
    address_shipping: {},
    allow_amount_higher: false,
    allow_amount_lower: false,
    allow_bunqme: false,
    amount_inquired: {currency: '', value: ''},
    amount_responded: {},
    attachment: [{id: 0}],
    batch_id: 0,
    bunqme_share_url: '',
    counterparty_alias: {
      avatar: {
        anchor_uuid: '',
        image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
        style: '',
        uuid: ''
      },
      bunq_me: {name: '', service: '', type: '', value: ''},
      country: '',
      display_name: '',
      iban: '',
      is_light: false,
      label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
      merchant_category_code: '',
      swift_account_number: '',
      swift_bic: '',
      transferwise_account_number: '',
      transferwise_bank_code: ''
    },
    created: '',
    description: '',
    event_id: 0,
    geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
    id: 0,
    merchant_reference: '',
    minimum_age: 0,
    monetary_account_id: 0,
    redirect_url: '',
    reference_split_the_bill: {
      BillingInvoice: {
        address: {},
        alias: {},
        category: '',
        chamber_of_commerce_number: '',
        counterparty_address: {},
        counterparty_alias: {},
        created: '',
        description: '',
        external_url: '',
        group: [
          {
            instance_description: '',
            item: [
              {
                billing_date: '',
                id: 0,
                quantity: 0,
                total_vat_exclusive: {},
                total_vat_inclusive: {},
                type_description: '',
                type_description_translated: '',
                unit_vat_exclusive: {},
                unit_vat_inclusive: {},
                vat: 0
              }
            ],
            product_vat_exclusive: {},
            product_vat_inclusive: {},
            type: '',
            type_description: '',
            type_description_translated: ''
          }
        ],
        id: 0,
        invoice_date: '',
        invoice_number: '',
        request_reference_split_the_bill: [{id: 0, type: ''}],
        status: '',
        total_vat: {},
        total_vat_exclusive: {},
        total_vat_inclusive: {},
        updated: '',
        vat_number: ''
      },
      DraftPayment: {
        entries: [
          {
            alias: {},
            amount: {},
            attachment: [{id: 0, monetary_account_id: 0}],
            counterparty_alias: {},
            description: '',
            id: 0,
            merchant_reference: '',
            type: ''
          }
        ],
        number_of_required_accepts: 0,
        previous_updated_timestamp: '',
        schedule: {
          object: {
            Payment: {
              address_billing: {},
              address_shipping: {},
              alias: {},
              allow_bunqto: false,
              amount: {},
              attachment: [{}],
              balance_after_mutation: {},
              batch_id: 0,
              bunqto_expiry: '',
              bunqto_share_url: '',
              bunqto_status: '',
              bunqto_sub_status: '',
              bunqto_time_responded: '',
              counterparty_alias: {},
              created: '',
              description: '',
              geolocation: {},
              id: 0,
              merchant_reference: '',
              monetary_account_id: 0,
              payment_auto_allocate_instance: {
                created: '',
                error_message: [],
                id: 0,
                payment_auto_allocate_id: 0,
                payment_batch: {payments: {Payment: []}},
                payment_id: 0,
                status: '',
                updated: ''
              },
              request_reference_split_the_bill: [{}],
              scheduled_id: 0,
              sub_type: '',
              type: '',
              updated: ''
            },
            PaymentBatch: {}
          },
          recurrence_size: 0,
          recurrence_unit: '',
          status: '',
          time_end: '',
          time_start: ''
        },
        status: ''
      },
      MasterCardAction: {
        alias: {},
        all_mastercard_action_refund: [
          {
            additional_information: {
              attachment: [{id: 0}],
              category: '',
              comment: '',
              reason: '',
              terms_and_conditions: ''
            },
            alias: {},
            amount: {},
            attachment: [{}],
            category: '',
            comment: '',
            counterparty_alias: {},
            created: '',
            description: '',
            id: 0,
            label_card: {
              expiry_date: '',
              label_user: {},
              second_line: '',
              status: '',
              type: '',
              uuid: ''
            },
            label_user_creator: {},
            mastercard_action_id: 0,
            reason: '',
            reference_mastercard_action_event: [{event_id: 0}],
            status: '',
            status_description: '',
            status_description_translated: '',
            status_together_url: '',
            sub_type: '',
            terms_and_conditions: '',
            time_refund: '',
            type: '',
            updated: ''
          }
        ],
        amount_billing: {},
        amount_converted: {},
        amount_fee: {},
        amount_local: {},
        amount_original_billing: {},
        amount_original_local: {},
        applied_limit: '',
        authorisation_status: '',
        authorisation_type: '',
        card_authorisation_id_response: '',
        card_id: 0,
        city: '',
        clearing_expiry_time: '',
        clearing_status: '',
        counterparty_alias: {},
        decision: '',
        decision_description: '',
        decision_description_translated: '',
        decision_together_url: '',
        description: '',
        eligible_whitelist_id: 0,
        id: 0,
        label_card: {},
        maturity_date: '',
        monetary_account_id: 0,
        pan_entry_mode_user: '',
        payment_status: '',
        pos_card_holder_presence: '',
        pos_card_presence: '',
        request_reference_split_the_bill: [{}],
        reservation_expiry_time: '',
        secure_code_id: 0,
        settlement_status: '',
        token_status: '',
        wallet_provider_id: ''
      },
      Payment: {},
      PaymentBatch: {},
      RequestResponse: {
        address_billing: {},
        address_shipping: {},
        alias: {},
        amount_inquired: {},
        amount_responded: {},
        attachment: [{content_type: '', description: '', urls: [{type: '', url: ''}]}],
        counterparty_alias: {},
        created: '',
        credit_scheme_identifier: '',
        description: '',
        eligible_whitelist_id: 0,
        event_id: 0,
        geolocation: {},
        id: 0,
        mandate_identifier: '',
        minimum_age: 0,
        monetary_account_id: 0,
        redirect_url: '',
        request_reference_split_the_bill: [{}],
        require_address: '',
        status: '',
        sub_type: '',
        time_expiry: '',
        time_refund_requested: '',
        time_refunded: '',
        time_responded: '',
        type: '',
        updated: '',
        user_refund_requested: {}
      },
      ScheduleInstance: {
        error_message: [],
        request_reference_split_the_bill: [{}],
        result_object: {Payment: {}, PaymentBatch: {}},
        scheduled_object: {},
        state: '',
        time_end: '',
        time_start: ''
      },
      TransferwisePayment: {
        alias: {},
        amount_source: {},
        amount_target: {},
        counterparty_alias: {},
        monetary_account_id: '',
        pay_in_reference: '',
        quote: {
          amount_fee: {},
          amount_source: {},
          amount_target: {},
          created: '',
          currency_source: '',
          currency_target: '',
          id: 0,
          quote_id: '',
          rate: '',
          time_delivery_estimate: '',
          time_expiry: '',
          updated: ''
        },
        rate: '',
        recipient_id: '',
        reference: '',
        status: '',
        status_transferwise: '',
        status_transferwise_issue: '',
        sub_status: '',
        time_delivery_estimate: ''
      },
      WhitelistResult: {
        error_message: [],
        id: 0,
        monetary_account_paying_id: 0,
        object: {draftPayment: {}, id: 0, requestResponse: {}},
        request_reference_split_the_bill: [{}],
        status: '',
        sub_status: '',
        whitelist: {}
      }
    },
    require_address: '',
    scheduled_id: 0,
    status: '',
    time_expiry: '',
    time_responded: '',
    updated: '',
    user_alias_created: {},
    user_alias_revoked: {},
    want_tip: false
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"address_billing":{"city":"","country":"","extra":"","house_number":"","is_user_address_updated":false,"mailbox_name":"","po_box":"","postal_code":"","province":"","street":""},"address_shipping":{},"allow_amount_higher":false,"allow_amount_lower":false,"allow_bunqme":false,"amount_inquired":{"currency":"","value":""},"amount_responded":{},"attachment":[{"id":0}],"batch_id":0,"bunqme_share_url":"","counterparty_alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"created":"","description":"","event_id":0,"geolocation":{"altitude":0,"latitude":0,"longitude":0,"radius":0},"id":0,"merchant_reference":"","minimum_age":0,"monetary_account_id":0,"redirect_url":"","reference_split_the_bill":{"BillingInvoice":{"address":{},"alias":{},"category":"","chamber_of_commerce_number":"","counterparty_address":{},"counterparty_alias":{},"created":"","description":"","external_url":"","group":[{"instance_description":"","item":[{"billing_date":"","id":0,"quantity":0,"total_vat_exclusive":{},"total_vat_inclusive":{},"type_description":"","type_description_translated":"","unit_vat_exclusive":{},"unit_vat_inclusive":{},"vat":0}],"product_vat_exclusive":{},"product_vat_inclusive":{},"type":"","type_description":"","type_description_translated":""}],"id":0,"invoice_date":"","invoice_number":"","request_reference_split_the_bill":[{"id":0,"type":""}],"status":"","total_vat":{},"total_vat_exclusive":{},"total_vat_inclusive":{},"updated":"","vat_number":""},"DraftPayment":{"entries":[{"alias":{},"amount":{},"attachment":[{"id":0,"monetary_account_id":0}],"counterparty_alias":{},"description":"","id":0,"merchant_reference":"","type":""}],"number_of_required_accepts":0,"previous_updated_timestamp":"","schedule":{"object":{"Payment":{"address_billing":{},"address_shipping":{},"alias":{},"allow_bunqto":false,"amount":{},"attachment":[{}],"balance_after_mutation":{},"batch_id":0,"bunqto_expiry":"","bunqto_share_url":"","bunqto_status":"","bunqto_sub_status":"","bunqto_time_responded":"","counterparty_alias":{},"created":"","description":"","geolocation":{},"id":0,"merchant_reference":"","monetary_account_id":0,"payment_auto_allocate_instance":{"created":"","error_message":[],"id":0,"payment_auto_allocate_id":0,"payment_batch":{"payments":{"Payment":[]}},"payment_id":0,"status":"","updated":""},"request_reference_split_the_bill":[{}],"scheduled_id":0,"sub_type":"","type":"","updated":""},"PaymentBatch":{}},"recurrence_size":0,"recurrence_unit":"","status":"","time_end":"","time_start":""},"status":""},"MasterCardAction":{"alias":{},"all_mastercard_action_refund":[{"additional_information":{"attachment":[{"id":0}],"category":"","comment":"","reason":"","terms_and_conditions":""},"alias":{},"amount":{},"attachment":[{}],"category":"","comment":"","counterparty_alias":{},"created":"","description":"","id":0,"label_card":{"expiry_date":"","label_user":{},"second_line":"","status":"","type":"","uuid":""},"label_user_creator":{},"mastercard_action_id":0,"reason":"","reference_mastercard_action_event":[{"event_id":0}],"status":"","status_description":"","status_description_translated":"","status_together_url":"","sub_type":"","terms_and_conditions":"","time_refund":"","type":"","updated":""}],"amount_billing":{},"amount_converted":{},"amount_fee":{},"amount_local":{},"amount_original_billing":{},"amount_original_local":{},"applied_limit":"","authorisation_status":"","authorisation_type":"","card_authorisation_id_response":"","card_id":0,"city":"","clearing_expiry_time":"","clearing_status":"","counterparty_alias":{},"decision":"","decision_description":"","decision_description_translated":"","decision_together_url":"","description":"","eligible_whitelist_id":0,"id":0,"label_card":{},"maturity_date":"","monetary_account_id":0,"pan_entry_mode_user":"","payment_status":"","pos_card_holder_presence":"","pos_card_presence":"","request_reference_split_the_bill":[{}],"reservation_expiry_time":"","secure_code_id":0,"settlement_status":"","token_status":"","wallet_provider_id":""},"Payment":{},"PaymentBatch":{},"RequestResponse":{"address_billing":{},"address_shipping":{},"alias":{},"amount_inquired":{},"amount_responded":{},"attachment":[{"content_type":"","description":"","urls":[{"type":"","url":""}]}],"counterparty_alias":{},"created":"","credit_scheme_identifier":"","description":"","eligible_whitelist_id":0,"event_id":0,"geolocation":{},"id":0,"mandate_identifier":"","minimum_age":0,"monetary_account_id":0,"redirect_url":"","request_reference_split_the_bill":[{}],"require_address":"","status":"","sub_type":"","time_expiry":"","time_refund_requested":"","time_refunded":"","time_responded":"","type":"","updated":"","user_refund_requested":{}},"ScheduleInstance":{"error_message":[],"request_reference_split_the_bill":[{}],"result_object":{"Payment":{},"PaymentBatch":{}},"scheduled_object":{},"state":"","time_end":"","time_start":""},"TransferwisePayment":{"alias":{},"amount_source":{},"amount_target":{},"counterparty_alias":{},"monetary_account_id":"","pay_in_reference":"","quote":{"amount_fee":{},"amount_source":{},"amount_target":{},"created":"","currency_source":"","currency_target":"","id":0,"quote_id":"","rate":"","time_delivery_estimate":"","time_expiry":"","updated":""},"rate":"","recipient_id":"","reference":"","status":"","status_transferwise":"","status_transferwise_issue":"","sub_status":"","time_delivery_estimate":""},"WhitelistResult":{"error_message":[],"id":0,"monetary_account_paying_id":0,"object":{"draftPayment":{},"id":0,"requestResponse":{}},"request_reference_split_the_bill":[{}],"status":"","sub_status":"","whitelist":{}}},"require_address":"","scheduled_id":0,"status":"","time_expiry":"","time_responded":"","updated":"","user_alias_created":{},"user_alias_revoked":{},"want_tip":false}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "address_billing": {\n    "city": "",\n    "country": "",\n    "extra": "",\n    "house_number": "",\n    "is_user_address_updated": false,\n    "mailbox_name": "",\n    "po_box": "",\n    "postal_code": "",\n    "province": "",\n    "street": ""\n  },\n  "address_shipping": {},\n  "allow_amount_higher": false,\n  "allow_amount_lower": false,\n  "allow_bunqme": false,\n  "amount_inquired": {\n    "currency": "",\n    "value": ""\n  },\n  "amount_responded": {},\n  "attachment": [\n    {\n      "id": 0\n    }\n  ],\n  "batch_id": 0,\n  "bunqme_share_url": "",\n  "counterparty_alias": {\n    "avatar": {\n      "anchor_uuid": "",\n      "image": [\n        {\n          "attachment_public_uuid": "",\n          "content_type": "",\n          "height": 0,\n          "width": 0\n        }\n      ],\n      "style": "",\n      "uuid": ""\n    },\n    "bunq_me": {\n      "name": "",\n      "service": "",\n      "type": "",\n      "value": ""\n    },\n    "country": "",\n    "display_name": "",\n    "iban": "",\n    "is_light": false,\n    "label_user": {\n      "avatar": {},\n      "country": "",\n      "display_name": "",\n      "public_nick_name": "",\n      "uuid": ""\n    },\n    "merchant_category_code": "",\n    "swift_account_number": "",\n    "swift_bic": "",\n    "transferwise_account_number": "",\n    "transferwise_bank_code": ""\n  },\n  "created": "",\n  "description": "",\n  "event_id": 0,\n  "geolocation": {\n    "altitude": 0,\n    "latitude": 0,\n    "longitude": 0,\n    "radius": 0\n  },\n  "id": 0,\n  "merchant_reference": "",\n  "minimum_age": 0,\n  "monetary_account_id": 0,\n  "redirect_url": "",\n  "reference_split_the_bill": {\n    "BillingInvoice": {\n      "address": {},\n      "alias": {},\n      "category": "",\n      "chamber_of_commerce_number": "",\n      "counterparty_address": {},\n      "counterparty_alias": {},\n      "created": "",\n      "description": "",\n      "external_url": "",\n      "group": [\n        {\n          "instance_description": "",\n          "item": [\n            {\n              "billing_date": "",\n              "id": 0,\n              "quantity": 0,\n              "total_vat_exclusive": {},\n              "total_vat_inclusive": {},\n              "type_description": "",\n              "type_description_translated": "",\n              "unit_vat_exclusive": {},\n              "unit_vat_inclusive": {},\n              "vat": 0\n            }\n          ],\n          "product_vat_exclusive": {},\n          "product_vat_inclusive": {},\n          "type": "",\n          "type_description": "",\n          "type_description_translated": ""\n        }\n      ],\n      "id": 0,\n      "invoice_date": "",\n      "invoice_number": "",\n      "request_reference_split_the_bill": [\n        {\n          "id": 0,\n          "type": ""\n        }\n      ],\n      "status": "",\n      "total_vat": {},\n      "total_vat_exclusive": {},\n      "total_vat_inclusive": {},\n      "updated": "",\n      "vat_number": ""\n    },\n    "DraftPayment": {\n      "entries": [\n        {\n          "alias": {},\n          "amount": {},\n          "attachment": [\n            {\n              "id": 0,\n              "monetary_account_id": 0\n            }\n          ],\n          "counterparty_alias": {},\n          "description": "",\n          "id": 0,\n          "merchant_reference": "",\n          "type": ""\n        }\n      ],\n      "number_of_required_accepts": 0,\n      "previous_updated_timestamp": "",\n      "schedule": {\n        "object": {\n          "Payment": {\n            "address_billing": {},\n            "address_shipping": {},\n            "alias": {},\n            "allow_bunqto": false,\n            "amount": {},\n            "attachment": [\n              {}\n            ],\n            "balance_after_mutation": {},\n            "batch_id": 0,\n            "bunqto_expiry": "",\n            "bunqto_share_url": "",\n            "bunqto_status": "",\n            "bunqto_sub_status": "",\n            "bunqto_time_responded": "",\n            "counterparty_alias": {},\n            "created": "",\n            "description": "",\n            "geolocation": {},\n            "id": 0,\n            "merchant_reference": "",\n            "monetary_account_id": 0,\n            "payment_auto_allocate_instance": {\n              "created": "",\n              "error_message": [],\n              "id": 0,\n              "payment_auto_allocate_id": 0,\n              "payment_batch": {\n                "payments": {\n                  "Payment": []\n                }\n              },\n              "payment_id": 0,\n              "status": "",\n              "updated": ""\n            },\n            "request_reference_split_the_bill": [\n              {}\n            ],\n            "scheduled_id": 0,\n            "sub_type": "",\n            "type": "",\n            "updated": ""\n          },\n          "PaymentBatch": {}\n        },\n        "recurrence_size": 0,\n        "recurrence_unit": "",\n        "status": "",\n        "time_end": "",\n        "time_start": ""\n      },\n      "status": ""\n    },\n    "MasterCardAction": {\n      "alias": {},\n      "all_mastercard_action_refund": [\n        {\n          "additional_information": {\n            "attachment": [\n              {\n                "id": 0\n              }\n            ],\n            "category": "",\n            "comment": "",\n            "reason": "",\n            "terms_and_conditions": ""\n          },\n          "alias": {},\n          "amount": {},\n          "attachment": [\n            {}\n          ],\n          "category": "",\n          "comment": "",\n          "counterparty_alias": {},\n          "created": "",\n          "description": "",\n          "id": 0,\n          "label_card": {\n            "expiry_date": "",\n            "label_user": {},\n            "second_line": "",\n            "status": "",\n            "type": "",\n            "uuid": ""\n          },\n          "label_user_creator": {},\n          "mastercard_action_id": 0,\n          "reason": "",\n          "reference_mastercard_action_event": [\n            {\n              "event_id": 0\n            }\n          ],\n          "status": "",\n          "status_description": "",\n          "status_description_translated": "",\n          "status_together_url": "",\n          "sub_type": "",\n          "terms_and_conditions": "",\n          "time_refund": "",\n          "type": "",\n          "updated": ""\n        }\n      ],\n      "amount_billing": {},\n      "amount_converted": {},\n      "amount_fee": {},\n      "amount_local": {},\n      "amount_original_billing": {},\n      "amount_original_local": {},\n      "applied_limit": "",\n      "authorisation_status": "",\n      "authorisation_type": "",\n      "card_authorisation_id_response": "",\n      "card_id": 0,\n      "city": "",\n      "clearing_expiry_time": "",\n      "clearing_status": "",\n      "counterparty_alias": {},\n      "decision": "",\n      "decision_description": "",\n      "decision_description_translated": "",\n      "decision_together_url": "",\n      "description": "",\n      "eligible_whitelist_id": 0,\n      "id": 0,\n      "label_card": {},\n      "maturity_date": "",\n      "monetary_account_id": 0,\n      "pan_entry_mode_user": "",\n      "payment_status": "",\n      "pos_card_holder_presence": "",\n      "pos_card_presence": "",\n      "request_reference_split_the_bill": [\n        {}\n      ],\n      "reservation_expiry_time": "",\n      "secure_code_id": 0,\n      "settlement_status": "",\n      "token_status": "",\n      "wallet_provider_id": ""\n    },\n    "Payment": {},\n    "PaymentBatch": {},\n    "RequestResponse": {\n      "address_billing": {},\n      "address_shipping": {},\n      "alias": {},\n      "amount_inquired": {},\n      "amount_responded": {},\n      "attachment": [\n        {\n          "content_type": "",\n          "description": "",\n          "urls": [\n            {\n              "type": "",\n              "url": ""\n            }\n          ]\n        }\n      ],\n      "counterparty_alias": {},\n      "created": "",\n      "credit_scheme_identifier": "",\n      "description": "",\n      "eligible_whitelist_id": 0,\n      "event_id": 0,\n      "geolocation": {},\n      "id": 0,\n      "mandate_identifier": "",\n      "minimum_age": 0,\n      "monetary_account_id": 0,\n      "redirect_url": "",\n      "request_reference_split_the_bill": [\n        {}\n      ],\n      "require_address": "",\n      "status": "",\n      "sub_type": "",\n      "time_expiry": "",\n      "time_refund_requested": "",\n      "time_refunded": "",\n      "time_responded": "",\n      "type": "",\n      "updated": "",\n      "user_refund_requested": {}\n    },\n    "ScheduleInstance": {\n      "error_message": [],\n      "request_reference_split_the_bill": [\n        {}\n      ],\n      "result_object": {\n        "Payment": {},\n        "PaymentBatch": {}\n      },\n      "scheduled_object": {},\n      "state": "",\n      "time_end": "",\n      "time_start": ""\n    },\n    "TransferwisePayment": {\n      "alias": {},\n      "amount_source": {},\n      "amount_target": {},\n      "counterparty_alias": {},\n      "monetary_account_id": "",\n      "pay_in_reference": "",\n      "quote": {\n        "amount_fee": {},\n        "amount_source": {},\n        "amount_target": {},\n        "created": "",\n        "currency_source": "",\n        "currency_target": "",\n        "id": 0,\n        "quote_id": "",\n        "rate": "",\n        "time_delivery_estimate": "",\n        "time_expiry": "",\n        "updated": ""\n      },\n      "rate": "",\n      "recipient_id": "",\n      "reference": "",\n      "status": "",\n      "status_transferwise": "",\n      "status_transferwise_issue": "",\n      "sub_status": "",\n      "time_delivery_estimate": ""\n    },\n    "WhitelistResult": {\n      "error_message": [],\n      "id": 0,\n      "monetary_account_paying_id": 0,\n      "object": {\n        "draftPayment": {},\n        "id": 0,\n        "requestResponse": {}\n      },\n      "request_reference_split_the_bill": [\n        {}\n      ],\n      "status": "",\n      "sub_status": "",\n      "whitelist": {}\n    }\n  },\n  "require_address": "",\n  "scheduled_id": 0,\n  "status": "",\n  "time_expiry": "",\n  "time_responded": "",\n  "updated": "",\n  "user_alias_created": {},\n  "user_alias_revoked": {},\n  "want_tip": false\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"allow_amount_higher\": false,\n  \"allow_amount_lower\": false,\n  \"allow_bunqme\": false,\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"id\": 0\n    }\n  ],\n  \"batch_id\": 0,\n  \"bunqme_share_url\": \"\",\n  \"counterparty_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {},\n      \"alias\": {},\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {},\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {},\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"require_address\": \"\",\n  \"scheduled_id\": 0,\n  \"status\": \"\",\n  \"time_expiry\": \"\",\n  \"time_responded\": \"\",\n  \"updated\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {},\n  \"want_tip\": false\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  address_billing: {
    city: '',
    country: '',
    extra: '',
    house_number: '',
    is_user_address_updated: false,
    mailbox_name: '',
    po_box: '',
    postal_code: '',
    province: '',
    street: ''
  },
  address_shipping: {},
  allow_amount_higher: false,
  allow_amount_lower: false,
  allow_bunqme: false,
  amount_inquired: {currency: '', value: ''},
  amount_responded: {},
  attachment: [{id: 0}],
  batch_id: 0,
  bunqme_share_url: '',
  counterparty_alias: {
    avatar: {
      anchor_uuid: '',
      image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
      style: '',
      uuid: ''
    },
    bunq_me: {name: '', service: '', type: '', value: ''},
    country: '',
    display_name: '',
    iban: '',
    is_light: false,
    label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
    merchant_category_code: '',
    swift_account_number: '',
    swift_bic: '',
    transferwise_account_number: '',
    transferwise_bank_code: ''
  },
  created: '',
  description: '',
  event_id: 0,
  geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
  id: 0,
  merchant_reference: '',
  minimum_age: 0,
  monetary_account_id: 0,
  redirect_url: '',
  reference_split_the_bill: {
    BillingInvoice: {
      address: {},
      alias: {},
      category: '',
      chamber_of_commerce_number: '',
      counterparty_address: {},
      counterparty_alias: {},
      created: '',
      description: '',
      external_url: '',
      group: [
        {
          instance_description: '',
          item: [
            {
              billing_date: '',
              id: 0,
              quantity: 0,
              total_vat_exclusive: {},
              total_vat_inclusive: {},
              type_description: '',
              type_description_translated: '',
              unit_vat_exclusive: {},
              unit_vat_inclusive: {},
              vat: 0
            }
          ],
          product_vat_exclusive: {},
          product_vat_inclusive: {},
          type: '',
          type_description: '',
          type_description_translated: ''
        }
      ],
      id: 0,
      invoice_date: '',
      invoice_number: '',
      request_reference_split_the_bill: [{id: 0, type: ''}],
      status: '',
      total_vat: {},
      total_vat_exclusive: {},
      total_vat_inclusive: {},
      updated: '',
      vat_number: ''
    },
    DraftPayment: {
      entries: [
        {
          alias: {},
          amount: {},
          attachment: [{id: 0, monetary_account_id: 0}],
          counterparty_alias: {},
          description: '',
          id: 0,
          merchant_reference: '',
          type: ''
        }
      ],
      number_of_required_accepts: 0,
      previous_updated_timestamp: '',
      schedule: {
        object: {
          Payment: {
            address_billing: {},
            address_shipping: {},
            alias: {},
            allow_bunqto: false,
            amount: {},
            attachment: [{}],
            balance_after_mutation: {},
            batch_id: 0,
            bunqto_expiry: '',
            bunqto_share_url: '',
            bunqto_status: '',
            bunqto_sub_status: '',
            bunqto_time_responded: '',
            counterparty_alias: {},
            created: '',
            description: '',
            geolocation: {},
            id: 0,
            merchant_reference: '',
            monetary_account_id: 0,
            payment_auto_allocate_instance: {
              created: '',
              error_message: [],
              id: 0,
              payment_auto_allocate_id: 0,
              payment_batch: {payments: {Payment: []}},
              payment_id: 0,
              status: '',
              updated: ''
            },
            request_reference_split_the_bill: [{}],
            scheduled_id: 0,
            sub_type: '',
            type: '',
            updated: ''
          },
          PaymentBatch: {}
        },
        recurrence_size: 0,
        recurrence_unit: '',
        status: '',
        time_end: '',
        time_start: ''
      },
      status: ''
    },
    MasterCardAction: {
      alias: {},
      all_mastercard_action_refund: [
        {
          additional_information: {
            attachment: [{id: 0}],
            category: '',
            comment: '',
            reason: '',
            terms_and_conditions: ''
          },
          alias: {},
          amount: {},
          attachment: [{}],
          category: '',
          comment: '',
          counterparty_alias: {},
          created: '',
          description: '',
          id: 0,
          label_card: {
            expiry_date: '',
            label_user: {},
            second_line: '',
            status: '',
            type: '',
            uuid: ''
          },
          label_user_creator: {},
          mastercard_action_id: 0,
          reason: '',
          reference_mastercard_action_event: [{event_id: 0}],
          status: '',
          status_description: '',
          status_description_translated: '',
          status_together_url: '',
          sub_type: '',
          terms_and_conditions: '',
          time_refund: '',
          type: '',
          updated: ''
        }
      ],
      amount_billing: {},
      amount_converted: {},
      amount_fee: {},
      amount_local: {},
      amount_original_billing: {},
      amount_original_local: {},
      applied_limit: '',
      authorisation_status: '',
      authorisation_type: '',
      card_authorisation_id_response: '',
      card_id: 0,
      city: '',
      clearing_expiry_time: '',
      clearing_status: '',
      counterparty_alias: {},
      decision: '',
      decision_description: '',
      decision_description_translated: '',
      decision_together_url: '',
      description: '',
      eligible_whitelist_id: 0,
      id: 0,
      label_card: {},
      maturity_date: '',
      monetary_account_id: 0,
      pan_entry_mode_user: '',
      payment_status: '',
      pos_card_holder_presence: '',
      pos_card_presence: '',
      request_reference_split_the_bill: [{}],
      reservation_expiry_time: '',
      secure_code_id: 0,
      settlement_status: '',
      token_status: '',
      wallet_provider_id: ''
    },
    Payment: {},
    PaymentBatch: {},
    RequestResponse: {
      address_billing: {},
      address_shipping: {},
      alias: {},
      amount_inquired: {},
      amount_responded: {},
      attachment: [{content_type: '', description: '', urls: [{type: '', url: ''}]}],
      counterparty_alias: {},
      created: '',
      credit_scheme_identifier: '',
      description: '',
      eligible_whitelist_id: 0,
      event_id: 0,
      geolocation: {},
      id: 0,
      mandate_identifier: '',
      minimum_age: 0,
      monetary_account_id: 0,
      redirect_url: '',
      request_reference_split_the_bill: [{}],
      require_address: '',
      status: '',
      sub_type: '',
      time_expiry: '',
      time_refund_requested: '',
      time_refunded: '',
      time_responded: '',
      type: '',
      updated: '',
      user_refund_requested: {}
    },
    ScheduleInstance: {
      error_message: [],
      request_reference_split_the_bill: [{}],
      result_object: {Payment: {}, PaymentBatch: {}},
      scheduled_object: {},
      state: '',
      time_end: '',
      time_start: ''
    },
    TransferwisePayment: {
      alias: {},
      amount_source: {},
      amount_target: {},
      counterparty_alias: {},
      monetary_account_id: '',
      pay_in_reference: '',
      quote: {
        amount_fee: {},
        amount_source: {},
        amount_target: {},
        created: '',
        currency_source: '',
        currency_target: '',
        id: 0,
        quote_id: '',
        rate: '',
        time_delivery_estimate: '',
        time_expiry: '',
        updated: ''
      },
      rate: '',
      recipient_id: '',
      reference: '',
      status: '',
      status_transferwise: '',
      status_transferwise_issue: '',
      sub_status: '',
      time_delivery_estimate: ''
    },
    WhitelistResult: {
      error_message: [],
      id: 0,
      monetary_account_paying_id: 0,
      object: {draftPayment: {}, id: 0, requestResponse: {}},
      request_reference_split_the_bill: [{}],
      status: '',
      sub_status: '',
      whitelist: {}
    }
  },
  require_address: '',
  scheduled_id: 0,
  status: '',
  time_expiry: '',
  time_responded: '',
  updated: '',
  user_alias_created: {},
  user_alias_revoked: {},
  want_tip: false
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    address_billing: {
      city: '',
      country: '',
      extra: '',
      house_number: '',
      is_user_address_updated: false,
      mailbox_name: '',
      po_box: '',
      postal_code: '',
      province: '',
      street: ''
    },
    address_shipping: {},
    allow_amount_higher: false,
    allow_amount_lower: false,
    allow_bunqme: false,
    amount_inquired: {currency: '', value: ''},
    amount_responded: {},
    attachment: [{id: 0}],
    batch_id: 0,
    bunqme_share_url: '',
    counterparty_alias: {
      avatar: {
        anchor_uuid: '',
        image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
        style: '',
        uuid: ''
      },
      bunq_me: {name: '', service: '', type: '', value: ''},
      country: '',
      display_name: '',
      iban: '',
      is_light: false,
      label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
      merchant_category_code: '',
      swift_account_number: '',
      swift_bic: '',
      transferwise_account_number: '',
      transferwise_bank_code: ''
    },
    created: '',
    description: '',
    event_id: 0,
    geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
    id: 0,
    merchant_reference: '',
    minimum_age: 0,
    monetary_account_id: 0,
    redirect_url: '',
    reference_split_the_bill: {
      BillingInvoice: {
        address: {},
        alias: {},
        category: '',
        chamber_of_commerce_number: '',
        counterparty_address: {},
        counterparty_alias: {},
        created: '',
        description: '',
        external_url: '',
        group: [
          {
            instance_description: '',
            item: [
              {
                billing_date: '',
                id: 0,
                quantity: 0,
                total_vat_exclusive: {},
                total_vat_inclusive: {},
                type_description: '',
                type_description_translated: '',
                unit_vat_exclusive: {},
                unit_vat_inclusive: {},
                vat: 0
              }
            ],
            product_vat_exclusive: {},
            product_vat_inclusive: {},
            type: '',
            type_description: '',
            type_description_translated: ''
          }
        ],
        id: 0,
        invoice_date: '',
        invoice_number: '',
        request_reference_split_the_bill: [{id: 0, type: ''}],
        status: '',
        total_vat: {},
        total_vat_exclusive: {},
        total_vat_inclusive: {},
        updated: '',
        vat_number: ''
      },
      DraftPayment: {
        entries: [
          {
            alias: {},
            amount: {},
            attachment: [{id: 0, monetary_account_id: 0}],
            counterparty_alias: {},
            description: '',
            id: 0,
            merchant_reference: '',
            type: ''
          }
        ],
        number_of_required_accepts: 0,
        previous_updated_timestamp: '',
        schedule: {
          object: {
            Payment: {
              address_billing: {},
              address_shipping: {},
              alias: {},
              allow_bunqto: false,
              amount: {},
              attachment: [{}],
              balance_after_mutation: {},
              batch_id: 0,
              bunqto_expiry: '',
              bunqto_share_url: '',
              bunqto_status: '',
              bunqto_sub_status: '',
              bunqto_time_responded: '',
              counterparty_alias: {},
              created: '',
              description: '',
              geolocation: {},
              id: 0,
              merchant_reference: '',
              monetary_account_id: 0,
              payment_auto_allocate_instance: {
                created: '',
                error_message: [],
                id: 0,
                payment_auto_allocate_id: 0,
                payment_batch: {payments: {Payment: []}},
                payment_id: 0,
                status: '',
                updated: ''
              },
              request_reference_split_the_bill: [{}],
              scheduled_id: 0,
              sub_type: '',
              type: '',
              updated: ''
            },
            PaymentBatch: {}
          },
          recurrence_size: 0,
          recurrence_unit: '',
          status: '',
          time_end: '',
          time_start: ''
        },
        status: ''
      },
      MasterCardAction: {
        alias: {},
        all_mastercard_action_refund: [
          {
            additional_information: {
              attachment: [{id: 0}],
              category: '',
              comment: '',
              reason: '',
              terms_and_conditions: ''
            },
            alias: {},
            amount: {},
            attachment: [{}],
            category: '',
            comment: '',
            counterparty_alias: {},
            created: '',
            description: '',
            id: 0,
            label_card: {
              expiry_date: '',
              label_user: {},
              second_line: '',
              status: '',
              type: '',
              uuid: ''
            },
            label_user_creator: {},
            mastercard_action_id: 0,
            reason: '',
            reference_mastercard_action_event: [{event_id: 0}],
            status: '',
            status_description: '',
            status_description_translated: '',
            status_together_url: '',
            sub_type: '',
            terms_and_conditions: '',
            time_refund: '',
            type: '',
            updated: ''
          }
        ],
        amount_billing: {},
        amount_converted: {},
        amount_fee: {},
        amount_local: {},
        amount_original_billing: {},
        amount_original_local: {},
        applied_limit: '',
        authorisation_status: '',
        authorisation_type: '',
        card_authorisation_id_response: '',
        card_id: 0,
        city: '',
        clearing_expiry_time: '',
        clearing_status: '',
        counterparty_alias: {},
        decision: '',
        decision_description: '',
        decision_description_translated: '',
        decision_together_url: '',
        description: '',
        eligible_whitelist_id: 0,
        id: 0,
        label_card: {},
        maturity_date: '',
        monetary_account_id: 0,
        pan_entry_mode_user: '',
        payment_status: '',
        pos_card_holder_presence: '',
        pos_card_presence: '',
        request_reference_split_the_bill: [{}],
        reservation_expiry_time: '',
        secure_code_id: 0,
        settlement_status: '',
        token_status: '',
        wallet_provider_id: ''
      },
      Payment: {},
      PaymentBatch: {},
      RequestResponse: {
        address_billing: {},
        address_shipping: {},
        alias: {},
        amount_inquired: {},
        amount_responded: {},
        attachment: [{content_type: '', description: '', urls: [{type: '', url: ''}]}],
        counterparty_alias: {},
        created: '',
        credit_scheme_identifier: '',
        description: '',
        eligible_whitelist_id: 0,
        event_id: 0,
        geolocation: {},
        id: 0,
        mandate_identifier: '',
        minimum_age: 0,
        monetary_account_id: 0,
        redirect_url: '',
        request_reference_split_the_bill: [{}],
        require_address: '',
        status: '',
        sub_type: '',
        time_expiry: '',
        time_refund_requested: '',
        time_refunded: '',
        time_responded: '',
        type: '',
        updated: '',
        user_refund_requested: {}
      },
      ScheduleInstance: {
        error_message: [],
        request_reference_split_the_bill: [{}],
        result_object: {Payment: {}, PaymentBatch: {}},
        scheduled_object: {},
        state: '',
        time_end: '',
        time_start: ''
      },
      TransferwisePayment: {
        alias: {},
        amount_source: {},
        amount_target: {},
        counterparty_alias: {},
        monetary_account_id: '',
        pay_in_reference: '',
        quote: {
          amount_fee: {},
          amount_source: {},
          amount_target: {},
          created: '',
          currency_source: '',
          currency_target: '',
          id: 0,
          quote_id: '',
          rate: '',
          time_delivery_estimate: '',
          time_expiry: '',
          updated: ''
        },
        rate: '',
        recipient_id: '',
        reference: '',
        status: '',
        status_transferwise: '',
        status_transferwise_issue: '',
        sub_status: '',
        time_delivery_estimate: ''
      },
      WhitelistResult: {
        error_message: [],
        id: 0,
        monetary_account_paying_id: 0,
        object: {draftPayment: {}, id: 0, requestResponse: {}},
        request_reference_split_the_bill: [{}],
        status: '',
        sub_status: '',
        whitelist: {}
      }
    },
    require_address: '',
    scheduled_id: 0,
    status: '',
    time_expiry: '',
    time_responded: '',
    updated: '',
    user_alias_created: {},
    user_alias_revoked: {},
    want_tip: false
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  address_billing: {
    city: '',
    country: '',
    extra: '',
    house_number: '',
    is_user_address_updated: false,
    mailbox_name: '',
    po_box: '',
    postal_code: '',
    province: '',
    street: ''
  },
  address_shipping: {},
  allow_amount_higher: false,
  allow_amount_lower: false,
  allow_bunqme: false,
  amount_inquired: {
    currency: '',
    value: ''
  },
  amount_responded: {},
  attachment: [
    {
      id: 0
    }
  ],
  batch_id: 0,
  bunqme_share_url: '',
  counterparty_alias: {
    avatar: {
      anchor_uuid: '',
      image: [
        {
          attachment_public_uuid: '',
          content_type: '',
          height: 0,
          width: 0
        }
      ],
      style: '',
      uuid: ''
    },
    bunq_me: {
      name: '',
      service: '',
      type: '',
      value: ''
    },
    country: '',
    display_name: '',
    iban: '',
    is_light: false,
    label_user: {
      avatar: {},
      country: '',
      display_name: '',
      public_nick_name: '',
      uuid: ''
    },
    merchant_category_code: '',
    swift_account_number: '',
    swift_bic: '',
    transferwise_account_number: '',
    transferwise_bank_code: ''
  },
  created: '',
  description: '',
  event_id: 0,
  geolocation: {
    altitude: 0,
    latitude: 0,
    longitude: 0,
    radius: 0
  },
  id: 0,
  merchant_reference: '',
  minimum_age: 0,
  monetary_account_id: 0,
  redirect_url: '',
  reference_split_the_bill: {
    BillingInvoice: {
      address: {},
      alias: {},
      category: '',
      chamber_of_commerce_number: '',
      counterparty_address: {},
      counterparty_alias: {},
      created: '',
      description: '',
      external_url: '',
      group: [
        {
          instance_description: '',
          item: [
            {
              billing_date: '',
              id: 0,
              quantity: 0,
              total_vat_exclusive: {},
              total_vat_inclusive: {},
              type_description: '',
              type_description_translated: '',
              unit_vat_exclusive: {},
              unit_vat_inclusive: {},
              vat: 0
            }
          ],
          product_vat_exclusive: {},
          product_vat_inclusive: {},
          type: '',
          type_description: '',
          type_description_translated: ''
        }
      ],
      id: 0,
      invoice_date: '',
      invoice_number: '',
      request_reference_split_the_bill: [
        {
          id: 0,
          type: ''
        }
      ],
      status: '',
      total_vat: {},
      total_vat_exclusive: {},
      total_vat_inclusive: {},
      updated: '',
      vat_number: ''
    },
    DraftPayment: {
      entries: [
        {
          alias: {},
          amount: {},
          attachment: [
            {
              id: 0,
              monetary_account_id: 0
            }
          ],
          counterparty_alias: {},
          description: '',
          id: 0,
          merchant_reference: '',
          type: ''
        }
      ],
      number_of_required_accepts: 0,
      previous_updated_timestamp: '',
      schedule: {
        object: {
          Payment: {
            address_billing: {},
            address_shipping: {},
            alias: {},
            allow_bunqto: false,
            amount: {},
            attachment: [
              {}
            ],
            balance_after_mutation: {},
            batch_id: 0,
            bunqto_expiry: '',
            bunqto_share_url: '',
            bunqto_status: '',
            bunqto_sub_status: '',
            bunqto_time_responded: '',
            counterparty_alias: {},
            created: '',
            description: '',
            geolocation: {},
            id: 0,
            merchant_reference: '',
            monetary_account_id: 0,
            payment_auto_allocate_instance: {
              created: '',
              error_message: [],
              id: 0,
              payment_auto_allocate_id: 0,
              payment_batch: {
                payments: {
                  Payment: []
                }
              },
              payment_id: 0,
              status: '',
              updated: ''
            },
            request_reference_split_the_bill: [
              {}
            ],
            scheduled_id: 0,
            sub_type: '',
            type: '',
            updated: ''
          },
          PaymentBatch: {}
        },
        recurrence_size: 0,
        recurrence_unit: '',
        status: '',
        time_end: '',
        time_start: ''
      },
      status: ''
    },
    MasterCardAction: {
      alias: {},
      all_mastercard_action_refund: [
        {
          additional_information: {
            attachment: [
              {
                id: 0
              }
            ],
            category: '',
            comment: '',
            reason: '',
            terms_and_conditions: ''
          },
          alias: {},
          amount: {},
          attachment: [
            {}
          ],
          category: '',
          comment: '',
          counterparty_alias: {},
          created: '',
          description: '',
          id: 0,
          label_card: {
            expiry_date: '',
            label_user: {},
            second_line: '',
            status: '',
            type: '',
            uuid: ''
          },
          label_user_creator: {},
          mastercard_action_id: 0,
          reason: '',
          reference_mastercard_action_event: [
            {
              event_id: 0
            }
          ],
          status: '',
          status_description: '',
          status_description_translated: '',
          status_together_url: '',
          sub_type: '',
          terms_and_conditions: '',
          time_refund: '',
          type: '',
          updated: ''
        }
      ],
      amount_billing: {},
      amount_converted: {},
      amount_fee: {},
      amount_local: {},
      amount_original_billing: {},
      amount_original_local: {},
      applied_limit: '',
      authorisation_status: '',
      authorisation_type: '',
      card_authorisation_id_response: '',
      card_id: 0,
      city: '',
      clearing_expiry_time: '',
      clearing_status: '',
      counterparty_alias: {},
      decision: '',
      decision_description: '',
      decision_description_translated: '',
      decision_together_url: '',
      description: '',
      eligible_whitelist_id: 0,
      id: 0,
      label_card: {},
      maturity_date: '',
      monetary_account_id: 0,
      pan_entry_mode_user: '',
      payment_status: '',
      pos_card_holder_presence: '',
      pos_card_presence: '',
      request_reference_split_the_bill: [
        {}
      ],
      reservation_expiry_time: '',
      secure_code_id: 0,
      settlement_status: '',
      token_status: '',
      wallet_provider_id: ''
    },
    Payment: {},
    PaymentBatch: {},
    RequestResponse: {
      address_billing: {},
      address_shipping: {},
      alias: {},
      amount_inquired: {},
      amount_responded: {},
      attachment: [
        {
          content_type: '',
          description: '',
          urls: [
            {
              type: '',
              url: ''
            }
          ]
        }
      ],
      counterparty_alias: {},
      created: '',
      credit_scheme_identifier: '',
      description: '',
      eligible_whitelist_id: 0,
      event_id: 0,
      geolocation: {},
      id: 0,
      mandate_identifier: '',
      minimum_age: 0,
      monetary_account_id: 0,
      redirect_url: '',
      request_reference_split_the_bill: [
        {}
      ],
      require_address: '',
      status: '',
      sub_type: '',
      time_expiry: '',
      time_refund_requested: '',
      time_refunded: '',
      time_responded: '',
      type: '',
      updated: '',
      user_refund_requested: {}
    },
    ScheduleInstance: {
      error_message: [],
      request_reference_split_the_bill: [
        {}
      ],
      result_object: {
        Payment: {},
        PaymentBatch: {}
      },
      scheduled_object: {},
      state: '',
      time_end: '',
      time_start: ''
    },
    TransferwisePayment: {
      alias: {},
      amount_source: {},
      amount_target: {},
      counterparty_alias: {},
      monetary_account_id: '',
      pay_in_reference: '',
      quote: {
        amount_fee: {},
        amount_source: {},
        amount_target: {},
        created: '',
        currency_source: '',
        currency_target: '',
        id: 0,
        quote_id: '',
        rate: '',
        time_delivery_estimate: '',
        time_expiry: '',
        updated: ''
      },
      rate: '',
      recipient_id: '',
      reference: '',
      status: '',
      status_transferwise: '',
      status_transferwise_issue: '',
      sub_status: '',
      time_delivery_estimate: ''
    },
    WhitelistResult: {
      error_message: [],
      id: 0,
      monetary_account_paying_id: 0,
      object: {
        draftPayment: {},
        id: 0,
        requestResponse: {}
      },
      request_reference_split_the_bill: [
        {}
      ],
      status: '',
      sub_status: '',
      whitelist: {}
    }
  },
  require_address: '',
  scheduled_id: 0,
  status: '',
  time_expiry: '',
  time_responded: '',
  updated: '',
  user_alias_created: {},
  user_alias_revoked: {},
  want_tip: false
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    address_billing: {
      city: '',
      country: '',
      extra: '',
      house_number: '',
      is_user_address_updated: false,
      mailbox_name: '',
      po_box: '',
      postal_code: '',
      province: '',
      street: ''
    },
    address_shipping: {},
    allow_amount_higher: false,
    allow_amount_lower: false,
    allow_bunqme: false,
    amount_inquired: {currency: '', value: ''},
    amount_responded: {},
    attachment: [{id: 0}],
    batch_id: 0,
    bunqme_share_url: '',
    counterparty_alias: {
      avatar: {
        anchor_uuid: '',
        image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
        style: '',
        uuid: ''
      },
      bunq_me: {name: '', service: '', type: '', value: ''},
      country: '',
      display_name: '',
      iban: '',
      is_light: false,
      label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
      merchant_category_code: '',
      swift_account_number: '',
      swift_bic: '',
      transferwise_account_number: '',
      transferwise_bank_code: ''
    },
    created: '',
    description: '',
    event_id: 0,
    geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
    id: 0,
    merchant_reference: '',
    minimum_age: 0,
    monetary_account_id: 0,
    redirect_url: '',
    reference_split_the_bill: {
      BillingInvoice: {
        address: {},
        alias: {},
        category: '',
        chamber_of_commerce_number: '',
        counterparty_address: {},
        counterparty_alias: {},
        created: '',
        description: '',
        external_url: '',
        group: [
          {
            instance_description: '',
            item: [
              {
                billing_date: '',
                id: 0,
                quantity: 0,
                total_vat_exclusive: {},
                total_vat_inclusive: {},
                type_description: '',
                type_description_translated: '',
                unit_vat_exclusive: {},
                unit_vat_inclusive: {},
                vat: 0
              }
            ],
            product_vat_exclusive: {},
            product_vat_inclusive: {},
            type: '',
            type_description: '',
            type_description_translated: ''
          }
        ],
        id: 0,
        invoice_date: '',
        invoice_number: '',
        request_reference_split_the_bill: [{id: 0, type: ''}],
        status: '',
        total_vat: {},
        total_vat_exclusive: {},
        total_vat_inclusive: {},
        updated: '',
        vat_number: ''
      },
      DraftPayment: {
        entries: [
          {
            alias: {},
            amount: {},
            attachment: [{id: 0, monetary_account_id: 0}],
            counterparty_alias: {},
            description: '',
            id: 0,
            merchant_reference: '',
            type: ''
          }
        ],
        number_of_required_accepts: 0,
        previous_updated_timestamp: '',
        schedule: {
          object: {
            Payment: {
              address_billing: {},
              address_shipping: {},
              alias: {},
              allow_bunqto: false,
              amount: {},
              attachment: [{}],
              balance_after_mutation: {},
              batch_id: 0,
              bunqto_expiry: '',
              bunqto_share_url: '',
              bunqto_status: '',
              bunqto_sub_status: '',
              bunqto_time_responded: '',
              counterparty_alias: {},
              created: '',
              description: '',
              geolocation: {},
              id: 0,
              merchant_reference: '',
              monetary_account_id: 0,
              payment_auto_allocate_instance: {
                created: '',
                error_message: [],
                id: 0,
                payment_auto_allocate_id: 0,
                payment_batch: {payments: {Payment: []}},
                payment_id: 0,
                status: '',
                updated: ''
              },
              request_reference_split_the_bill: [{}],
              scheduled_id: 0,
              sub_type: '',
              type: '',
              updated: ''
            },
            PaymentBatch: {}
          },
          recurrence_size: 0,
          recurrence_unit: '',
          status: '',
          time_end: '',
          time_start: ''
        },
        status: ''
      },
      MasterCardAction: {
        alias: {},
        all_mastercard_action_refund: [
          {
            additional_information: {
              attachment: [{id: 0}],
              category: '',
              comment: '',
              reason: '',
              terms_and_conditions: ''
            },
            alias: {},
            amount: {},
            attachment: [{}],
            category: '',
            comment: '',
            counterparty_alias: {},
            created: '',
            description: '',
            id: 0,
            label_card: {
              expiry_date: '',
              label_user: {},
              second_line: '',
              status: '',
              type: '',
              uuid: ''
            },
            label_user_creator: {},
            mastercard_action_id: 0,
            reason: '',
            reference_mastercard_action_event: [{event_id: 0}],
            status: '',
            status_description: '',
            status_description_translated: '',
            status_together_url: '',
            sub_type: '',
            terms_and_conditions: '',
            time_refund: '',
            type: '',
            updated: ''
          }
        ],
        amount_billing: {},
        amount_converted: {},
        amount_fee: {},
        amount_local: {},
        amount_original_billing: {},
        amount_original_local: {},
        applied_limit: '',
        authorisation_status: '',
        authorisation_type: '',
        card_authorisation_id_response: '',
        card_id: 0,
        city: '',
        clearing_expiry_time: '',
        clearing_status: '',
        counterparty_alias: {},
        decision: '',
        decision_description: '',
        decision_description_translated: '',
        decision_together_url: '',
        description: '',
        eligible_whitelist_id: 0,
        id: 0,
        label_card: {},
        maturity_date: '',
        monetary_account_id: 0,
        pan_entry_mode_user: '',
        payment_status: '',
        pos_card_holder_presence: '',
        pos_card_presence: '',
        request_reference_split_the_bill: [{}],
        reservation_expiry_time: '',
        secure_code_id: 0,
        settlement_status: '',
        token_status: '',
        wallet_provider_id: ''
      },
      Payment: {},
      PaymentBatch: {},
      RequestResponse: {
        address_billing: {},
        address_shipping: {},
        alias: {},
        amount_inquired: {},
        amount_responded: {},
        attachment: [{content_type: '', description: '', urls: [{type: '', url: ''}]}],
        counterparty_alias: {},
        created: '',
        credit_scheme_identifier: '',
        description: '',
        eligible_whitelist_id: 0,
        event_id: 0,
        geolocation: {},
        id: 0,
        mandate_identifier: '',
        minimum_age: 0,
        monetary_account_id: 0,
        redirect_url: '',
        request_reference_split_the_bill: [{}],
        require_address: '',
        status: '',
        sub_type: '',
        time_expiry: '',
        time_refund_requested: '',
        time_refunded: '',
        time_responded: '',
        type: '',
        updated: '',
        user_refund_requested: {}
      },
      ScheduleInstance: {
        error_message: [],
        request_reference_split_the_bill: [{}],
        result_object: {Payment: {}, PaymentBatch: {}},
        scheduled_object: {},
        state: '',
        time_end: '',
        time_start: ''
      },
      TransferwisePayment: {
        alias: {},
        amount_source: {},
        amount_target: {},
        counterparty_alias: {},
        monetary_account_id: '',
        pay_in_reference: '',
        quote: {
          amount_fee: {},
          amount_source: {},
          amount_target: {},
          created: '',
          currency_source: '',
          currency_target: '',
          id: 0,
          quote_id: '',
          rate: '',
          time_delivery_estimate: '',
          time_expiry: '',
          updated: ''
        },
        rate: '',
        recipient_id: '',
        reference: '',
        status: '',
        status_transferwise: '',
        status_transferwise_issue: '',
        sub_status: '',
        time_delivery_estimate: ''
      },
      WhitelistResult: {
        error_message: [],
        id: 0,
        monetary_account_paying_id: 0,
        object: {draftPayment: {}, id: 0, requestResponse: {}},
        request_reference_split_the_bill: [{}],
        status: '',
        sub_status: '',
        whitelist: {}
      }
    },
    require_address: '',
    scheduled_id: 0,
    status: '',
    time_expiry: '',
    time_responded: '',
    updated: '',
    user_alias_created: {},
    user_alias_revoked: {},
    want_tip: false
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"address_billing":{"city":"","country":"","extra":"","house_number":"","is_user_address_updated":false,"mailbox_name":"","po_box":"","postal_code":"","province":"","street":""},"address_shipping":{},"allow_amount_higher":false,"allow_amount_lower":false,"allow_bunqme":false,"amount_inquired":{"currency":"","value":""},"amount_responded":{},"attachment":[{"id":0}],"batch_id":0,"bunqme_share_url":"","counterparty_alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"created":"","description":"","event_id":0,"geolocation":{"altitude":0,"latitude":0,"longitude":0,"radius":0},"id":0,"merchant_reference":"","minimum_age":0,"monetary_account_id":0,"redirect_url":"","reference_split_the_bill":{"BillingInvoice":{"address":{},"alias":{},"category":"","chamber_of_commerce_number":"","counterparty_address":{},"counterparty_alias":{},"created":"","description":"","external_url":"","group":[{"instance_description":"","item":[{"billing_date":"","id":0,"quantity":0,"total_vat_exclusive":{},"total_vat_inclusive":{},"type_description":"","type_description_translated":"","unit_vat_exclusive":{},"unit_vat_inclusive":{},"vat":0}],"product_vat_exclusive":{},"product_vat_inclusive":{},"type":"","type_description":"","type_description_translated":""}],"id":0,"invoice_date":"","invoice_number":"","request_reference_split_the_bill":[{"id":0,"type":""}],"status":"","total_vat":{},"total_vat_exclusive":{},"total_vat_inclusive":{},"updated":"","vat_number":""},"DraftPayment":{"entries":[{"alias":{},"amount":{},"attachment":[{"id":0,"monetary_account_id":0}],"counterparty_alias":{},"description":"","id":0,"merchant_reference":"","type":""}],"number_of_required_accepts":0,"previous_updated_timestamp":"","schedule":{"object":{"Payment":{"address_billing":{},"address_shipping":{},"alias":{},"allow_bunqto":false,"amount":{},"attachment":[{}],"balance_after_mutation":{},"batch_id":0,"bunqto_expiry":"","bunqto_share_url":"","bunqto_status":"","bunqto_sub_status":"","bunqto_time_responded":"","counterparty_alias":{},"created":"","description":"","geolocation":{},"id":0,"merchant_reference":"","monetary_account_id":0,"payment_auto_allocate_instance":{"created":"","error_message":[],"id":0,"payment_auto_allocate_id":0,"payment_batch":{"payments":{"Payment":[]}},"payment_id":0,"status":"","updated":""},"request_reference_split_the_bill":[{}],"scheduled_id":0,"sub_type":"","type":"","updated":""},"PaymentBatch":{}},"recurrence_size":0,"recurrence_unit":"","status":"","time_end":"","time_start":""},"status":""},"MasterCardAction":{"alias":{},"all_mastercard_action_refund":[{"additional_information":{"attachment":[{"id":0}],"category":"","comment":"","reason":"","terms_and_conditions":""},"alias":{},"amount":{},"attachment":[{}],"category":"","comment":"","counterparty_alias":{},"created":"","description":"","id":0,"label_card":{"expiry_date":"","label_user":{},"second_line":"","status":"","type":"","uuid":""},"label_user_creator":{},"mastercard_action_id":0,"reason":"","reference_mastercard_action_event":[{"event_id":0}],"status":"","status_description":"","status_description_translated":"","status_together_url":"","sub_type":"","terms_and_conditions":"","time_refund":"","type":"","updated":""}],"amount_billing":{},"amount_converted":{},"amount_fee":{},"amount_local":{},"amount_original_billing":{},"amount_original_local":{},"applied_limit":"","authorisation_status":"","authorisation_type":"","card_authorisation_id_response":"","card_id":0,"city":"","clearing_expiry_time":"","clearing_status":"","counterparty_alias":{},"decision":"","decision_description":"","decision_description_translated":"","decision_together_url":"","description":"","eligible_whitelist_id":0,"id":0,"label_card":{},"maturity_date":"","monetary_account_id":0,"pan_entry_mode_user":"","payment_status":"","pos_card_holder_presence":"","pos_card_presence":"","request_reference_split_the_bill":[{}],"reservation_expiry_time":"","secure_code_id":0,"settlement_status":"","token_status":"","wallet_provider_id":""},"Payment":{},"PaymentBatch":{},"RequestResponse":{"address_billing":{},"address_shipping":{},"alias":{},"amount_inquired":{},"amount_responded":{},"attachment":[{"content_type":"","description":"","urls":[{"type":"","url":""}]}],"counterparty_alias":{},"created":"","credit_scheme_identifier":"","description":"","eligible_whitelist_id":0,"event_id":0,"geolocation":{},"id":0,"mandate_identifier":"","minimum_age":0,"monetary_account_id":0,"redirect_url":"","request_reference_split_the_bill":[{}],"require_address":"","status":"","sub_type":"","time_expiry":"","time_refund_requested":"","time_refunded":"","time_responded":"","type":"","updated":"","user_refund_requested":{}},"ScheduleInstance":{"error_message":[],"request_reference_split_the_bill":[{}],"result_object":{"Payment":{},"PaymentBatch":{}},"scheduled_object":{},"state":"","time_end":"","time_start":""},"TransferwisePayment":{"alias":{},"amount_source":{},"amount_target":{},"counterparty_alias":{},"monetary_account_id":"","pay_in_reference":"","quote":{"amount_fee":{},"amount_source":{},"amount_target":{},"created":"","currency_source":"","currency_target":"","id":0,"quote_id":"","rate":"","time_delivery_estimate":"","time_expiry":"","updated":""},"rate":"","recipient_id":"","reference":"","status":"","status_transferwise":"","status_transferwise_issue":"","sub_status":"","time_delivery_estimate":""},"WhitelistResult":{"error_message":[],"id":0,"monetary_account_paying_id":0,"object":{"draftPayment":{},"id":0,"requestResponse":{}},"request_reference_split_the_bill":[{}],"status":"","sub_status":"","whitelist":{}}},"require_address":"","scheduled_id":0,"status":"","time_expiry":"","time_responded":"","updated":"","user_alias_created":{},"user_alias_revoked":{},"want_tip":false}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"address_billing": @{ @"city": @"", @"country": @"", @"extra": @"", @"house_number": @"", @"is_user_address_updated": @NO, @"mailbox_name": @"", @"po_box": @"", @"postal_code": @"", @"province": @"", @"street": @"" },
                              @"address_shipping": @{  },
                              @"allow_amount_higher": @NO,
                              @"allow_amount_lower": @NO,
                              @"allow_bunqme": @NO,
                              @"amount_inquired": @{ @"currency": @"", @"value": @"" },
                              @"amount_responded": @{  },
                              @"attachment": @[ @{ @"id": @0 } ],
                              @"batch_id": @0,
                              @"bunqme_share_url": @"",
                              @"counterparty_alias": @{ @"avatar": @{ @"anchor_uuid": @"", @"image": @[ @{ @"attachment_public_uuid": @"", @"content_type": @"", @"height": @0, @"width": @0 } ], @"style": @"", @"uuid": @"" }, @"bunq_me": @{ @"name": @"", @"service": @"", @"type": @"", @"value": @"" }, @"country": @"", @"display_name": @"", @"iban": @"", @"is_light": @NO, @"label_user": @{ @"avatar": @{  }, @"country": @"", @"display_name": @"", @"public_nick_name": @"", @"uuid": @"" }, @"merchant_category_code": @"", @"swift_account_number": @"", @"swift_bic": @"", @"transferwise_account_number": @"", @"transferwise_bank_code": @"" },
                              @"created": @"",
                              @"description": @"",
                              @"event_id": @0,
                              @"geolocation": @{ @"altitude": @0, @"latitude": @0, @"longitude": @0, @"radius": @0 },
                              @"id": @0,
                              @"merchant_reference": @"",
                              @"minimum_age": @0,
                              @"monetary_account_id": @0,
                              @"redirect_url": @"",
                              @"reference_split_the_bill": @{ @"BillingInvoice": @{ @"address": @{  }, @"alias": @{  }, @"category": @"", @"chamber_of_commerce_number": @"", @"counterparty_address": @{  }, @"counterparty_alias": @{  }, @"created": @"", @"description": @"", @"external_url": @"", @"group": @[ @{ @"instance_description": @"", @"item": @[ @{ @"billing_date": @"", @"id": @0, @"quantity": @0, @"total_vat_exclusive": @{  }, @"total_vat_inclusive": @{  }, @"type_description": @"", @"type_description_translated": @"", @"unit_vat_exclusive": @{  }, @"unit_vat_inclusive": @{  }, @"vat": @0 } ], @"product_vat_exclusive": @{  }, @"product_vat_inclusive": @{  }, @"type": @"", @"type_description": @"", @"type_description_translated": @"" } ], @"id": @0, @"invoice_date": @"", @"invoice_number": @"", @"request_reference_split_the_bill": @[ @{ @"id": @0, @"type": @"" } ], @"status": @"", @"total_vat": @{  }, @"total_vat_exclusive": @{  }, @"total_vat_inclusive": @{  }, @"updated": @"", @"vat_number": @"" }, @"DraftPayment": @{ @"entries": @[ @{ @"alias": @{  }, @"amount": @{  }, @"attachment": @[ @{ @"id": @0, @"monetary_account_id": @0 } ], @"counterparty_alias": @{  }, @"description": @"", @"id": @0, @"merchant_reference": @"", @"type": @"" } ], @"number_of_required_accepts": @0, @"previous_updated_timestamp": @"", @"schedule": @{ @"object": @{ @"Payment": @{ @"address_billing": @{  }, @"address_shipping": @{  }, @"alias": @{  }, @"allow_bunqto": @NO, @"amount": @{  }, @"attachment": @[ @{  } ], @"balance_after_mutation": @{  }, @"batch_id": @0, @"bunqto_expiry": @"", @"bunqto_share_url": @"", @"bunqto_status": @"", @"bunqto_sub_status": @"", @"bunqto_time_responded": @"", @"counterparty_alias": @{  }, @"created": @"", @"description": @"", @"geolocation": @{  }, @"id": @0, @"merchant_reference": @"", @"monetary_account_id": @0, @"payment_auto_allocate_instance": @{ @"created": @"", @"error_message": @[  ], @"id": @0, @"payment_auto_allocate_id": @0, @"payment_batch": @{ @"payments": @{ @"Payment": @[  ] } }, @"payment_id": @0, @"status": @"", @"updated": @"" }, @"request_reference_split_the_bill": @[ @{  } ], @"scheduled_id": @0, @"sub_type": @"", @"type": @"", @"updated": @"" }, @"PaymentBatch": @{  } }, @"recurrence_size": @0, @"recurrence_unit": @"", @"status": @"", @"time_end": @"", @"time_start": @"" }, @"status": @"" }, @"MasterCardAction": @{ @"alias": @{  }, @"all_mastercard_action_refund": @[ @{ @"additional_information": @{ @"attachment": @[ @{ @"id": @0 } ], @"category": @"", @"comment": @"", @"reason": @"", @"terms_and_conditions": @"" }, @"alias": @{  }, @"amount": @{  }, @"attachment": @[ @{  } ], @"category": @"", @"comment": @"", @"counterparty_alias": @{  }, @"created": @"", @"description": @"", @"id": @0, @"label_card": @{ @"expiry_date": @"", @"label_user": @{  }, @"second_line": @"", @"status": @"", @"type": @"", @"uuid": @"" }, @"label_user_creator": @{  }, @"mastercard_action_id": @0, @"reason": @"", @"reference_mastercard_action_event": @[ @{ @"event_id": @0 } ], @"status": @"", @"status_description": @"", @"status_description_translated": @"", @"status_together_url": @"", @"sub_type": @"", @"terms_and_conditions": @"", @"time_refund": @"", @"type": @"", @"updated": @"" } ], @"amount_billing": @{  }, @"amount_converted": @{  }, @"amount_fee": @{  }, @"amount_local": @{  }, @"amount_original_billing": @{  }, @"amount_original_local": @{  }, @"applied_limit": @"", @"authorisation_status": @"", @"authorisation_type": @"", @"card_authorisation_id_response": @"", @"card_id": @0, @"city": @"", @"clearing_expiry_time": @"", @"clearing_status": @"", @"counterparty_alias": @{  }, @"decision": @"", @"decision_description": @"", @"decision_description_translated": @"", @"decision_together_url": @"", @"description": @"", @"eligible_whitelist_id": @0, @"id": @0, @"label_card": @{  }, @"maturity_date": @"", @"monetary_account_id": @0, @"pan_entry_mode_user": @"", @"payment_status": @"", @"pos_card_holder_presence": @"", @"pos_card_presence": @"", @"request_reference_split_the_bill": @[ @{  } ], @"reservation_expiry_time": @"", @"secure_code_id": @0, @"settlement_status": @"", @"token_status": @"", @"wallet_provider_id": @"" }, @"Payment": @{  }, @"PaymentBatch": @{  }, @"RequestResponse": @{ @"address_billing": @{  }, @"address_shipping": @{  }, @"alias": @{  }, @"amount_inquired": @{  }, @"amount_responded": @{  }, @"attachment": @[ @{ @"content_type": @"", @"description": @"", @"urls": @[ @{ @"type": @"", @"url": @"" } ] } ], @"counterparty_alias": @{  }, @"created": @"", @"credit_scheme_identifier": @"", @"description": @"", @"eligible_whitelist_id": @0, @"event_id": @0, @"geolocation": @{  }, @"id": @0, @"mandate_identifier": @"", @"minimum_age": @0, @"monetary_account_id": @0, @"redirect_url": @"", @"request_reference_split_the_bill": @[ @{  } ], @"require_address": @"", @"status": @"", @"sub_type": @"", @"time_expiry": @"", @"time_refund_requested": @"", @"time_refunded": @"", @"time_responded": @"", @"type": @"", @"updated": @"", @"user_refund_requested": @{  } }, @"ScheduleInstance": @{ @"error_message": @[  ], @"request_reference_split_the_bill": @[ @{  } ], @"result_object": @{ @"Payment": @{  }, @"PaymentBatch": @{  } }, @"scheduled_object": @{  }, @"state": @"", @"time_end": @"", @"time_start": @"" }, @"TransferwisePayment": @{ @"alias": @{  }, @"amount_source": @{  }, @"amount_target": @{  }, @"counterparty_alias": @{  }, @"monetary_account_id": @"", @"pay_in_reference": @"", @"quote": @{ @"amount_fee": @{  }, @"amount_source": @{  }, @"amount_target": @{  }, @"created": @"", @"currency_source": @"", @"currency_target": @"", @"id": @0, @"quote_id": @"", @"rate": @"", @"time_delivery_estimate": @"", @"time_expiry": @"", @"updated": @"" }, @"rate": @"", @"recipient_id": @"", @"reference": @"", @"status": @"", @"status_transferwise": @"", @"status_transferwise_issue": @"", @"sub_status": @"", @"time_delivery_estimate": @"" }, @"WhitelistResult": @{ @"error_message": @[  ], @"id": @0, @"monetary_account_paying_id": @0, @"object": @{ @"draftPayment": @{  }, @"id": @0, @"requestResponse": @{  } }, @"request_reference_split_the_bill": @[ @{  } ], @"status": @"", @"sub_status": @"", @"whitelist": @{  } } },
                              @"require_address": @"",
                              @"scheduled_id": @0,
                              @"status": @"",
                              @"time_expiry": @"",
                              @"time_responded": @"",
                              @"updated": @"",
                              @"user_alias_created": @{  },
                              @"user_alias_revoked": @{  },
                              @"want_tip": @NO };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"allow_amount_higher\": false,\n  \"allow_amount_lower\": false,\n  \"allow_bunqme\": false,\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"id\": 0\n    }\n  ],\n  \"batch_id\": 0,\n  \"bunqme_share_url\": \"\",\n  \"counterparty_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {},\n      \"alias\": {},\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {},\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {},\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"require_address\": \"\",\n  \"scheduled_id\": 0,\n  \"status\": \"\",\n  \"time_expiry\": \"\",\n  \"time_responded\": \"\",\n  \"updated\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {},\n  \"want_tip\": false\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'address_billing' => [
        'city' => '',
        'country' => '',
        'extra' => '',
        'house_number' => '',
        'is_user_address_updated' => null,
        'mailbox_name' => '',
        'po_box' => '',
        'postal_code' => '',
        'province' => '',
        'street' => ''
    ],
    'address_shipping' => [
        
    ],
    'allow_amount_higher' => null,
    'allow_amount_lower' => null,
    'allow_bunqme' => null,
    'amount_inquired' => [
        'currency' => '',
        'value' => ''
    ],
    'amount_responded' => [
        
    ],
    'attachment' => [
        [
                'id' => 0
        ]
    ],
    'batch_id' => 0,
    'bunqme_share_url' => '',
    'counterparty_alias' => [
        'avatar' => [
                'anchor_uuid' => '',
                'image' => [
                                [
                                                                'attachment_public_uuid' => '',
                                                                'content_type' => '',
                                                                'height' => 0,
                                                                'width' => 0
                                ]
                ],
                'style' => '',
                'uuid' => ''
        ],
        'bunq_me' => [
                'name' => '',
                'service' => '',
                'type' => '',
                'value' => ''
        ],
        'country' => '',
        'display_name' => '',
        'iban' => '',
        'is_light' => null,
        'label_user' => [
                'avatar' => [
                                
                ],
                'country' => '',
                'display_name' => '',
                'public_nick_name' => '',
                'uuid' => ''
        ],
        'merchant_category_code' => '',
        'swift_account_number' => '',
        'swift_bic' => '',
        'transferwise_account_number' => '',
        'transferwise_bank_code' => ''
    ],
    'created' => '',
    'description' => '',
    'event_id' => 0,
    'geolocation' => [
        'altitude' => 0,
        'latitude' => 0,
        'longitude' => 0,
        'radius' => 0
    ],
    'id' => 0,
    'merchant_reference' => '',
    'minimum_age' => 0,
    'monetary_account_id' => 0,
    'redirect_url' => '',
    'reference_split_the_bill' => [
        'BillingInvoice' => [
                'address' => [
                                
                ],
                'alias' => [
                                
                ],
                'category' => '',
                'chamber_of_commerce_number' => '',
                'counterparty_address' => [
                                
                ],
                'counterparty_alias' => [
                                
                ],
                'created' => '',
                'description' => '',
                'external_url' => '',
                'group' => [
                                [
                                                                'instance_description' => '',
                                                                'item' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'billing_date' => '',
                                                                                                                                                                                                                                                                'id' => 0,
                                                                                                                                                                                                                                                                'quantity' => 0,
                                                                                                                                                                                                                                                                'total_vat_exclusive' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'total_vat_inclusive' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'type_description' => '',
                                                                                                                                                                                                                                                                'type_description_translated' => '',
                                                                                                                                                                                                                                                                'unit_vat_exclusive' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'unit_vat_inclusive' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'vat' => 0
                                                                                                                                ]
                                                                ],
                                                                'product_vat_exclusive' => [
                                                                                                                                
                                                                ],
                                                                'product_vat_inclusive' => [
                                                                                                                                
                                                                ],
                                                                'type' => '',
                                                                'type_description' => '',
                                                                'type_description_translated' => ''
                                ]
                ],
                'id' => 0,
                'invoice_date' => '',
                'invoice_number' => '',
                'request_reference_split_the_bill' => [
                                [
                                                                'id' => 0,
                                                                'type' => ''
                                ]
                ],
                'status' => '',
                'total_vat' => [
                                
                ],
                'total_vat_exclusive' => [
                                
                ],
                'total_vat_inclusive' => [
                                
                ],
                'updated' => '',
                'vat_number' => ''
        ],
        'DraftPayment' => [
                'entries' => [
                                [
                                                                'alias' => [
                                                                                                                                
                                                                ],
                                                                'amount' => [
                                                                                                                                
                                                                ],
                                                                'attachment' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'id' => 0,
                                                                                                                                                                                                                                                                'monetary_account_id' => 0
                                                                                                                                ]
                                                                ],
                                                                'counterparty_alias' => [
                                                                                                                                
                                                                ],
                                                                'description' => '',
                                                                'id' => 0,
                                                                'merchant_reference' => '',
                                                                'type' => ''
                                ]
                ],
                'number_of_required_accepts' => 0,
                'previous_updated_timestamp' => '',
                'schedule' => [
                                'object' => [
                                                                'Payment' => [
                                                                                                                                'address_billing' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'address_shipping' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'alias' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'allow_bunqto' => null,
                                                                                                                                'amount' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'attachment' => [
                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'balance_after_mutation' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'batch_id' => 0,
                                                                                                                                'bunqto_expiry' => '',
                                                                                                                                'bunqto_share_url' => '',
                                                                                                                                'bunqto_status' => '',
                                                                                                                                'bunqto_sub_status' => '',
                                                                                                                                'bunqto_time_responded' => '',
                                                                                                                                'counterparty_alias' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'created' => '',
                                                                                                                                'description' => '',
                                                                                                                                'geolocation' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'id' => 0,
                                                                                                                                'merchant_reference' => '',
                                                                                                                                'monetary_account_id' => 0,
                                                                                                                                'payment_auto_allocate_instance' => [
                                                                                                                                                                                                                                                                'created' => '',
                                                                                                                                                                                                                                                                'error_message' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'id' => 0,
                                                                                                                                                                                                                                                                'payment_auto_allocate_id' => 0,
                                                                                                                                                                                                                                                                'payment_batch' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'payments' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'Payment' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'payment_id' => 0,
                                                                                                                                                                                                                                                                'status' => '',
                                                                                                                                                                                                                                                                'updated' => ''
                                                                                                                                ],
                                                                                                                                'request_reference_split_the_bill' => [
                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'scheduled_id' => 0,
                                                                                                                                'sub_type' => '',
                                                                                                                                'type' => '',
                                                                                                                                'updated' => ''
                                                                ],
                                                                'PaymentBatch' => [
                                                                                                                                
                                                                ]
                                ],
                                'recurrence_size' => 0,
                                'recurrence_unit' => '',
                                'status' => '',
                                'time_end' => '',
                                'time_start' => ''
                ],
                'status' => ''
        ],
        'MasterCardAction' => [
                'alias' => [
                                
                ],
                'all_mastercard_action_refund' => [
                                [
                                                                'additional_information' => [
                                                                                                                                'attachment' => [
                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'id' => 0
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'category' => '',
                                                                                                                                'comment' => '',
                                                                                                                                'reason' => '',
                                                                                                                                'terms_and_conditions' => ''
                                                                ],
                                                                'alias' => [
                                                                                                                                
                                                                ],
                                                                'amount' => [
                                                                                                                                
                                                                ],
                                                                'attachment' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'category' => '',
                                                                'comment' => '',
                                                                'counterparty_alias' => [
                                                                                                                                
                                                                ],
                                                                'created' => '',
                                                                'description' => '',
                                                                'id' => 0,
                                                                'label_card' => [
                                                                                                                                'expiry_date' => '',
                                                                                                                                'label_user' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'second_line' => '',
                                                                                                                                'status' => '',
                                                                                                                                'type' => '',
                                                                                                                                'uuid' => ''
                                                                ],
                                                                'label_user_creator' => [
                                                                                                                                
                                                                ],
                                                                'mastercard_action_id' => 0,
                                                                'reason' => '',
                                                                'reference_mastercard_action_event' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'event_id' => 0
                                                                                                                                ]
                                                                ],
                                                                'status' => '',
                                                                'status_description' => '',
                                                                'status_description_translated' => '',
                                                                'status_together_url' => '',
                                                                'sub_type' => '',
                                                                'terms_and_conditions' => '',
                                                                'time_refund' => '',
                                                                'type' => '',
                                                                'updated' => ''
                                ]
                ],
                'amount_billing' => [
                                
                ],
                'amount_converted' => [
                                
                ],
                'amount_fee' => [
                                
                ],
                'amount_local' => [
                                
                ],
                'amount_original_billing' => [
                                
                ],
                'amount_original_local' => [
                                
                ],
                'applied_limit' => '',
                'authorisation_status' => '',
                'authorisation_type' => '',
                'card_authorisation_id_response' => '',
                'card_id' => 0,
                'city' => '',
                'clearing_expiry_time' => '',
                'clearing_status' => '',
                'counterparty_alias' => [
                                
                ],
                'decision' => '',
                'decision_description' => '',
                'decision_description_translated' => '',
                'decision_together_url' => '',
                'description' => '',
                'eligible_whitelist_id' => 0,
                'id' => 0,
                'label_card' => [
                                
                ],
                'maturity_date' => '',
                'monetary_account_id' => 0,
                'pan_entry_mode_user' => '',
                'payment_status' => '',
                'pos_card_holder_presence' => '',
                'pos_card_presence' => '',
                'request_reference_split_the_bill' => [
                                [
                                                                
                                ]
                ],
                'reservation_expiry_time' => '',
                'secure_code_id' => 0,
                'settlement_status' => '',
                'token_status' => '',
                'wallet_provider_id' => ''
        ],
        'Payment' => [
                
        ],
        'PaymentBatch' => [
                
        ],
        'RequestResponse' => [
                'address_billing' => [
                                
                ],
                'address_shipping' => [
                                
                ],
                'alias' => [
                                
                ],
                'amount_inquired' => [
                                
                ],
                'amount_responded' => [
                                
                ],
                'attachment' => [
                                [
                                                                'content_type' => '',
                                                                'description' => '',
                                                                'urls' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'type' => '',
                                                                                                                                                                                                                                                                'url' => ''
                                                                                                                                ]
                                                                ]
                                ]
                ],
                'counterparty_alias' => [
                                
                ],
                'created' => '',
                'credit_scheme_identifier' => '',
                'description' => '',
                'eligible_whitelist_id' => 0,
                'event_id' => 0,
                'geolocation' => [
                                
                ],
                'id' => 0,
                'mandate_identifier' => '',
                'minimum_age' => 0,
                'monetary_account_id' => 0,
                'redirect_url' => '',
                'request_reference_split_the_bill' => [
                                [
                                                                
                                ]
                ],
                'require_address' => '',
                'status' => '',
                'sub_type' => '',
                'time_expiry' => '',
                'time_refund_requested' => '',
                'time_refunded' => '',
                'time_responded' => '',
                'type' => '',
                'updated' => '',
                'user_refund_requested' => [
                                
                ]
        ],
        'ScheduleInstance' => [
                'error_message' => [
                                
                ],
                'request_reference_split_the_bill' => [
                                [
                                                                
                                ]
                ],
                'result_object' => [
                                'Payment' => [
                                                                
                                ],
                                'PaymentBatch' => [
                                                                
                                ]
                ],
                'scheduled_object' => [
                                
                ],
                'state' => '',
                'time_end' => '',
                'time_start' => ''
        ],
        'TransferwisePayment' => [
                'alias' => [
                                
                ],
                'amount_source' => [
                                
                ],
                'amount_target' => [
                                
                ],
                'counterparty_alias' => [
                                
                ],
                'monetary_account_id' => '',
                'pay_in_reference' => '',
                'quote' => [
                                'amount_fee' => [
                                                                
                                ],
                                'amount_source' => [
                                                                
                                ],
                                'amount_target' => [
                                                                
                                ],
                                'created' => '',
                                'currency_source' => '',
                                'currency_target' => '',
                                'id' => 0,
                                'quote_id' => '',
                                'rate' => '',
                                'time_delivery_estimate' => '',
                                'time_expiry' => '',
                                'updated' => ''
                ],
                'rate' => '',
                'recipient_id' => '',
                'reference' => '',
                'status' => '',
                'status_transferwise' => '',
                'status_transferwise_issue' => '',
                'sub_status' => '',
                'time_delivery_estimate' => ''
        ],
        'WhitelistResult' => [
                'error_message' => [
                                
                ],
                'id' => 0,
                'monetary_account_paying_id' => 0,
                'object' => [
                                'draftPayment' => [
                                                                
                                ],
                                'id' => 0,
                                'requestResponse' => [
                                                                
                                ]
                ],
                'request_reference_split_the_bill' => [
                                [
                                                                
                                ]
                ],
                'status' => '',
                'sub_status' => '',
                'whitelist' => [
                                
                ]
        ]
    ],
    'require_address' => '',
    'scheduled_id' => 0,
    'status' => '',
    'time_expiry' => '',
    'time_responded' => '',
    'updated' => '',
    'user_alias_created' => [
        
    ],
    'user_alias_revoked' => [
        
    ],
    'want_tip' => null
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId', [
  'body' => '{
  "address_billing": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_shipping": {},
  "allow_amount_higher": false,
  "allow_amount_lower": false,
  "allow_bunqme": false,
  "amount_inquired": {
    "currency": "",
    "value": ""
  },
  "amount_responded": {},
  "attachment": [
    {
      "id": 0
    }
  ],
  "batch_id": 0,
  "bunqme_share_url": "",
  "counterparty_alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "created": "",
  "description": "",
  "event_id": 0,
  "geolocation": {
    "altitude": 0,
    "latitude": 0,
    "longitude": 0,
    "radius": 0
  },
  "id": 0,
  "merchant_reference": "",
  "minimum_age": 0,
  "monetary_account_id": 0,
  "redirect_url": "",
  "reference_split_the_bill": {
    "BillingInvoice": {
      "address": {},
      "alias": {},
      "category": "",
      "chamber_of_commerce_number": "",
      "counterparty_address": {},
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "external_url": "",
      "group": [
        {
          "instance_description": "",
          "item": [
            {
              "billing_date": "",
              "id": 0,
              "quantity": 0,
              "total_vat_exclusive": {},
              "total_vat_inclusive": {},
              "type_description": "",
              "type_description_translated": "",
              "unit_vat_exclusive": {},
              "unit_vat_inclusive": {},
              "vat": 0
            }
          ],
          "product_vat_exclusive": {},
          "product_vat_inclusive": {},
          "type": "",
          "type_description": "",
          "type_description_translated": ""
        }
      ],
      "id": 0,
      "invoice_date": "",
      "invoice_number": "",
      "request_reference_split_the_bill": [
        {
          "id": 0,
          "type": ""
        }
      ],
      "status": "",
      "total_vat": {},
      "total_vat_exclusive": {},
      "total_vat_inclusive": {},
      "updated": "",
      "vat_number": ""
    },
    "DraftPayment": {
      "entries": [
        {
          "alias": {},
          "amount": {},
          "attachment": [
            {
              "id": 0,
              "monetary_account_id": 0
            }
          ],
          "counterparty_alias": {},
          "description": "",
          "id": 0,
          "merchant_reference": "",
          "type": ""
        }
      ],
      "number_of_required_accepts": 0,
      "previous_updated_timestamp": "",
      "schedule": {
        "object": {
          "Payment": {
            "address_billing": {},
            "address_shipping": {},
            "alias": {},
            "allow_bunqto": false,
            "amount": {},
            "attachment": [
              {}
            ],
            "balance_after_mutation": {},
            "batch_id": 0,
            "bunqto_expiry": "",
            "bunqto_share_url": "",
            "bunqto_status": "",
            "bunqto_sub_status": "",
            "bunqto_time_responded": "",
            "counterparty_alias": {},
            "created": "",
            "description": "",
            "geolocation": {},
            "id": 0,
            "merchant_reference": "",
            "monetary_account_id": 0,
            "payment_auto_allocate_instance": {
              "created": "",
              "error_message": [],
              "id": 0,
              "payment_auto_allocate_id": 0,
              "payment_batch": {
                "payments": {
                  "Payment": []
                }
              },
              "payment_id": 0,
              "status": "",
              "updated": ""
            },
            "request_reference_split_the_bill": [
              {}
            ],
            "scheduled_id": 0,
            "sub_type": "",
            "type": "",
            "updated": ""
          },
          "PaymentBatch": {}
        },
        "recurrence_size": 0,
        "recurrence_unit": "",
        "status": "",
        "time_end": "",
        "time_start": ""
      },
      "status": ""
    },
    "MasterCardAction": {
      "alias": {},
      "all_mastercard_action_refund": [
        {
          "additional_information": {
            "attachment": [
              {
                "id": 0
              }
            ],
            "category": "",
            "comment": "",
            "reason": "",
            "terms_and_conditions": ""
          },
          "alias": {},
          "amount": {},
          "attachment": [
            {}
          ],
          "category": "",
          "comment": "",
          "counterparty_alias": {},
          "created": "",
          "description": "",
          "id": 0,
          "label_card": {
            "expiry_date": "",
            "label_user": {},
            "second_line": "",
            "status": "",
            "type": "",
            "uuid": ""
          },
          "label_user_creator": {},
          "mastercard_action_id": 0,
          "reason": "",
          "reference_mastercard_action_event": [
            {
              "event_id": 0
            }
          ],
          "status": "",
          "status_description": "",
          "status_description_translated": "",
          "status_together_url": "",
          "sub_type": "",
          "terms_and_conditions": "",
          "time_refund": "",
          "type": "",
          "updated": ""
        }
      ],
      "amount_billing": {},
      "amount_converted": {},
      "amount_fee": {},
      "amount_local": {},
      "amount_original_billing": {},
      "amount_original_local": {},
      "applied_limit": "",
      "authorisation_status": "",
      "authorisation_type": "",
      "card_authorisation_id_response": "",
      "card_id": 0,
      "city": "",
      "clearing_expiry_time": "",
      "clearing_status": "",
      "counterparty_alias": {},
      "decision": "",
      "decision_description": "",
      "decision_description_translated": "",
      "decision_together_url": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "id": 0,
      "label_card": {},
      "maturity_date": "",
      "monetary_account_id": 0,
      "pan_entry_mode_user": "",
      "payment_status": "",
      "pos_card_holder_presence": "",
      "pos_card_presence": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "reservation_expiry_time": "",
      "secure_code_id": 0,
      "settlement_status": "",
      "token_status": "",
      "wallet_provider_id": ""
    },
    "Payment": {},
    "PaymentBatch": {},
    "RequestResponse": {
      "address_billing": {},
      "address_shipping": {},
      "alias": {},
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "content_type": "",
          "description": "",
          "urls": [
            {
              "type": "",
              "url": ""
            }
          ]
        }
      ],
      "counterparty_alias": {},
      "created": "",
      "credit_scheme_identifier": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "mandate_identifier": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "require_address": "",
      "status": "",
      "sub_type": "",
      "time_expiry": "",
      "time_refund_requested": "",
      "time_refunded": "",
      "time_responded": "",
      "type": "",
      "updated": "",
      "user_refund_requested": {}
    },
    "ScheduleInstance": {
      "error_message": [],
      "request_reference_split_the_bill": [
        {}
      ],
      "result_object": {
        "Payment": {},
        "PaymentBatch": {}
      },
      "scheduled_object": {},
      "state": "",
      "time_end": "",
      "time_start": ""
    },
    "TransferwisePayment": {
      "alias": {},
      "amount_source": {},
      "amount_target": {},
      "counterparty_alias": {},
      "monetary_account_id": "",
      "pay_in_reference": "",
      "quote": {
        "amount_fee": {},
        "amount_source": {},
        "amount_target": {},
        "created": "",
        "currency_source": "",
        "currency_target": "",
        "id": 0,
        "quote_id": "",
        "rate": "",
        "time_delivery_estimate": "",
        "time_expiry": "",
        "updated": ""
      },
      "rate": "",
      "recipient_id": "",
      "reference": "",
      "status": "",
      "status_transferwise": "",
      "status_transferwise_issue": "",
      "sub_status": "",
      "time_delivery_estimate": ""
    },
    "WhitelistResult": {
      "error_message": [],
      "id": 0,
      "monetary_account_paying_id": 0,
      "object": {
        "draftPayment": {},
        "id": 0,
        "requestResponse": {}
      },
      "request_reference_split_the_bill": [
        {}
      ],
      "status": "",
      "sub_status": "",
      "whitelist": {}
    }
  },
  "require_address": "",
  "scheduled_id": 0,
  "status": "",
  "time_expiry": "",
  "time_responded": "",
  "updated": "",
  "user_alias_created": {},
  "user_alias_revoked": {},
  "want_tip": false
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'address_billing' => [
    'city' => '',
    'country' => '',
    'extra' => '',
    'house_number' => '',
    'is_user_address_updated' => null,
    'mailbox_name' => '',
    'po_box' => '',
    'postal_code' => '',
    'province' => '',
    'street' => ''
  ],
  'address_shipping' => [
    
  ],
  'allow_amount_higher' => null,
  'allow_amount_lower' => null,
  'allow_bunqme' => null,
  'amount_inquired' => [
    'currency' => '',
    'value' => ''
  ],
  'amount_responded' => [
    
  ],
  'attachment' => [
    [
        'id' => 0
    ]
  ],
  'batch_id' => 0,
  'bunqme_share_url' => '',
  'counterparty_alias' => [
    'avatar' => [
        'anchor_uuid' => '',
        'image' => [
                [
                                'attachment_public_uuid' => '',
                                'content_type' => '',
                                'height' => 0,
                                'width' => 0
                ]
        ],
        'style' => '',
        'uuid' => ''
    ],
    'bunq_me' => [
        'name' => '',
        'service' => '',
        'type' => '',
        'value' => ''
    ],
    'country' => '',
    'display_name' => '',
    'iban' => '',
    'is_light' => null,
    'label_user' => [
        'avatar' => [
                
        ],
        'country' => '',
        'display_name' => '',
        'public_nick_name' => '',
        'uuid' => ''
    ],
    'merchant_category_code' => '',
    'swift_account_number' => '',
    'swift_bic' => '',
    'transferwise_account_number' => '',
    'transferwise_bank_code' => ''
  ],
  'created' => '',
  'description' => '',
  'event_id' => 0,
  'geolocation' => [
    'altitude' => 0,
    'latitude' => 0,
    'longitude' => 0,
    'radius' => 0
  ],
  'id' => 0,
  'merchant_reference' => '',
  'minimum_age' => 0,
  'monetary_account_id' => 0,
  'redirect_url' => '',
  'reference_split_the_bill' => [
    'BillingInvoice' => [
        'address' => [
                
        ],
        'alias' => [
                
        ],
        'category' => '',
        'chamber_of_commerce_number' => '',
        'counterparty_address' => [
                
        ],
        'counterparty_alias' => [
                
        ],
        'created' => '',
        'description' => '',
        'external_url' => '',
        'group' => [
                [
                                'instance_description' => '',
                                'item' => [
                                                                [
                                                                                                                                'billing_date' => '',
                                                                                                                                'id' => 0,
                                                                                                                                'quantity' => 0,
                                                                                                                                'total_vat_exclusive' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'total_vat_inclusive' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'type_description' => '',
                                                                                                                                'type_description_translated' => '',
                                                                                                                                'unit_vat_exclusive' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'unit_vat_inclusive' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'vat' => 0
                                                                ]
                                ],
                                'product_vat_exclusive' => [
                                                                
                                ],
                                'product_vat_inclusive' => [
                                                                
                                ],
                                'type' => '',
                                'type_description' => '',
                                'type_description_translated' => ''
                ]
        ],
        'id' => 0,
        'invoice_date' => '',
        'invoice_number' => '',
        'request_reference_split_the_bill' => [
                [
                                'id' => 0,
                                'type' => ''
                ]
        ],
        'status' => '',
        'total_vat' => [
                
        ],
        'total_vat_exclusive' => [
                
        ],
        'total_vat_inclusive' => [
                
        ],
        'updated' => '',
        'vat_number' => ''
    ],
    'DraftPayment' => [
        'entries' => [
                [
                                'alias' => [
                                                                
                                ],
                                'amount' => [
                                                                
                                ],
                                'attachment' => [
                                                                [
                                                                                                                                'id' => 0,
                                                                                                                                'monetary_account_id' => 0
                                                                ]
                                ],
                                'counterparty_alias' => [
                                                                
                                ],
                                'description' => '',
                                'id' => 0,
                                'merchant_reference' => '',
                                'type' => ''
                ]
        ],
        'number_of_required_accepts' => 0,
        'previous_updated_timestamp' => '',
        'schedule' => [
                'object' => [
                                'Payment' => [
                                                                'address_billing' => [
                                                                                                                                
                                                                ],
                                                                'address_shipping' => [
                                                                                                                                
                                                                ],
                                                                'alias' => [
                                                                                                                                
                                                                ],
                                                                'allow_bunqto' => null,
                                                                'amount' => [
                                                                                                                                
                                                                ],
                                                                'attachment' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'balance_after_mutation' => [
                                                                                                                                
                                                                ],
                                                                'batch_id' => 0,
                                                                'bunqto_expiry' => '',
                                                                'bunqto_share_url' => '',
                                                                'bunqto_status' => '',
                                                                'bunqto_sub_status' => '',
                                                                'bunqto_time_responded' => '',
                                                                'counterparty_alias' => [
                                                                                                                                
                                                                ],
                                                                'created' => '',
                                                                'description' => '',
                                                                'geolocation' => [
                                                                                                                                
                                                                ],
                                                                'id' => 0,
                                                                'merchant_reference' => '',
                                                                'monetary_account_id' => 0,
                                                                'payment_auto_allocate_instance' => [
                                                                                                                                'created' => '',
                                                                                                                                'error_message' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'id' => 0,
                                                                                                                                'payment_auto_allocate_id' => 0,
                                                                                                                                'payment_batch' => [
                                                                                                                                                                                                                                                                'payments' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'Payment' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'payment_id' => 0,
                                                                                                                                'status' => '',
                                                                                                                                'updated' => ''
                                                                ],
                                                                'request_reference_split_the_bill' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'scheduled_id' => 0,
                                                                'sub_type' => '',
                                                                'type' => '',
                                                                'updated' => ''
                                ],
                                'PaymentBatch' => [
                                                                
                                ]
                ],
                'recurrence_size' => 0,
                'recurrence_unit' => '',
                'status' => '',
                'time_end' => '',
                'time_start' => ''
        ],
        'status' => ''
    ],
    'MasterCardAction' => [
        'alias' => [
                
        ],
        'all_mastercard_action_refund' => [
                [
                                'additional_information' => [
                                                                'attachment' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'id' => 0
                                                                                                                                ]
                                                                ],
                                                                'category' => '',
                                                                'comment' => '',
                                                                'reason' => '',
                                                                'terms_and_conditions' => ''
                                ],
                                'alias' => [
                                                                
                                ],
                                'amount' => [
                                                                
                                ],
                                'attachment' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'category' => '',
                                'comment' => '',
                                'counterparty_alias' => [
                                                                
                                ],
                                'created' => '',
                                'description' => '',
                                'id' => 0,
                                'label_card' => [
                                                                'expiry_date' => '',
                                                                'label_user' => [
                                                                                                                                
                                                                ],
                                                                'second_line' => '',
                                                                'status' => '',
                                                                'type' => '',
                                                                'uuid' => ''
                                ],
                                'label_user_creator' => [
                                                                
                                ],
                                'mastercard_action_id' => 0,
                                'reason' => '',
                                'reference_mastercard_action_event' => [
                                                                [
                                                                                                                                'event_id' => 0
                                                                ]
                                ],
                                'status' => '',
                                'status_description' => '',
                                'status_description_translated' => '',
                                'status_together_url' => '',
                                'sub_type' => '',
                                'terms_and_conditions' => '',
                                'time_refund' => '',
                                'type' => '',
                                'updated' => ''
                ]
        ],
        'amount_billing' => [
                
        ],
        'amount_converted' => [
                
        ],
        'amount_fee' => [
                
        ],
        'amount_local' => [
                
        ],
        'amount_original_billing' => [
                
        ],
        'amount_original_local' => [
                
        ],
        'applied_limit' => '',
        'authorisation_status' => '',
        'authorisation_type' => '',
        'card_authorisation_id_response' => '',
        'card_id' => 0,
        'city' => '',
        'clearing_expiry_time' => '',
        'clearing_status' => '',
        'counterparty_alias' => [
                
        ],
        'decision' => '',
        'decision_description' => '',
        'decision_description_translated' => '',
        'decision_together_url' => '',
        'description' => '',
        'eligible_whitelist_id' => 0,
        'id' => 0,
        'label_card' => [
                
        ],
        'maturity_date' => '',
        'monetary_account_id' => 0,
        'pan_entry_mode_user' => '',
        'payment_status' => '',
        'pos_card_holder_presence' => '',
        'pos_card_presence' => '',
        'request_reference_split_the_bill' => [
                [
                                
                ]
        ],
        'reservation_expiry_time' => '',
        'secure_code_id' => 0,
        'settlement_status' => '',
        'token_status' => '',
        'wallet_provider_id' => ''
    ],
    'Payment' => [
        
    ],
    'PaymentBatch' => [
        
    ],
    'RequestResponse' => [
        'address_billing' => [
                
        ],
        'address_shipping' => [
                
        ],
        'alias' => [
                
        ],
        'amount_inquired' => [
                
        ],
        'amount_responded' => [
                
        ],
        'attachment' => [
                [
                                'content_type' => '',
                                'description' => '',
                                'urls' => [
                                                                [
                                                                                                                                'type' => '',
                                                                                                                                'url' => ''
                                                                ]
                                ]
                ]
        ],
        'counterparty_alias' => [
                
        ],
        'created' => '',
        'credit_scheme_identifier' => '',
        'description' => '',
        'eligible_whitelist_id' => 0,
        'event_id' => 0,
        'geolocation' => [
                
        ],
        'id' => 0,
        'mandate_identifier' => '',
        'minimum_age' => 0,
        'monetary_account_id' => 0,
        'redirect_url' => '',
        'request_reference_split_the_bill' => [
                [
                                
                ]
        ],
        'require_address' => '',
        'status' => '',
        'sub_type' => '',
        'time_expiry' => '',
        'time_refund_requested' => '',
        'time_refunded' => '',
        'time_responded' => '',
        'type' => '',
        'updated' => '',
        'user_refund_requested' => [
                
        ]
    ],
    'ScheduleInstance' => [
        'error_message' => [
                
        ],
        'request_reference_split_the_bill' => [
                [
                                
                ]
        ],
        'result_object' => [
                'Payment' => [
                                
                ],
                'PaymentBatch' => [
                                
                ]
        ],
        'scheduled_object' => [
                
        ],
        'state' => '',
        'time_end' => '',
        'time_start' => ''
    ],
    'TransferwisePayment' => [
        'alias' => [
                
        ],
        'amount_source' => [
                
        ],
        'amount_target' => [
                
        ],
        'counterparty_alias' => [
                
        ],
        'monetary_account_id' => '',
        'pay_in_reference' => '',
        'quote' => [
                'amount_fee' => [
                                
                ],
                'amount_source' => [
                                
                ],
                'amount_target' => [
                                
                ],
                'created' => '',
                'currency_source' => '',
                'currency_target' => '',
                'id' => 0,
                'quote_id' => '',
                'rate' => '',
                'time_delivery_estimate' => '',
                'time_expiry' => '',
                'updated' => ''
        ],
        'rate' => '',
        'recipient_id' => '',
        'reference' => '',
        'status' => '',
        'status_transferwise' => '',
        'status_transferwise_issue' => '',
        'sub_status' => '',
        'time_delivery_estimate' => ''
    ],
    'WhitelistResult' => [
        'error_message' => [
                
        ],
        'id' => 0,
        'monetary_account_paying_id' => 0,
        'object' => [
                'draftPayment' => [
                                
                ],
                'id' => 0,
                'requestResponse' => [
                                
                ]
        ],
        'request_reference_split_the_bill' => [
                [
                                
                ]
        ],
        'status' => '',
        'sub_status' => '',
        'whitelist' => [
                
        ]
    ]
  ],
  'require_address' => '',
  'scheduled_id' => 0,
  'status' => '',
  'time_expiry' => '',
  'time_responded' => '',
  'updated' => '',
  'user_alias_created' => [
    
  ],
  'user_alias_revoked' => [
    
  ],
  'want_tip' => null
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'address_billing' => [
    'city' => '',
    'country' => '',
    'extra' => '',
    'house_number' => '',
    'is_user_address_updated' => null,
    'mailbox_name' => '',
    'po_box' => '',
    'postal_code' => '',
    'province' => '',
    'street' => ''
  ],
  'address_shipping' => [
    
  ],
  'allow_amount_higher' => null,
  'allow_amount_lower' => null,
  'allow_bunqme' => null,
  'amount_inquired' => [
    'currency' => '',
    'value' => ''
  ],
  'amount_responded' => [
    
  ],
  'attachment' => [
    [
        'id' => 0
    ]
  ],
  'batch_id' => 0,
  'bunqme_share_url' => '',
  'counterparty_alias' => [
    'avatar' => [
        'anchor_uuid' => '',
        'image' => [
                [
                                'attachment_public_uuid' => '',
                                'content_type' => '',
                                'height' => 0,
                                'width' => 0
                ]
        ],
        'style' => '',
        'uuid' => ''
    ],
    'bunq_me' => [
        'name' => '',
        'service' => '',
        'type' => '',
        'value' => ''
    ],
    'country' => '',
    'display_name' => '',
    'iban' => '',
    'is_light' => null,
    'label_user' => [
        'avatar' => [
                
        ],
        'country' => '',
        'display_name' => '',
        'public_nick_name' => '',
        'uuid' => ''
    ],
    'merchant_category_code' => '',
    'swift_account_number' => '',
    'swift_bic' => '',
    'transferwise_account_number' => '',
    'transferwise_bank_code' => ''
  ],
  'created' => '',
  'description' => '',
  'event_id' => 0,
  'geolocation' => [
    'altitude' => 0,
    'latitude' => 0,
    'longitude' => 0,
    'radius' => 0
  ],
  'id' => 0,
  'merchant_reference' => '',
  'minimum_age' => 0,
  'monetary_account_id' => 0,
  'redirect_url' => '',
  'reference_split_the_bill' => [
    'BillingInvoice' => [
        'address' => [
                
        ],
        'alias' => [
                
        ],
        'category' => '',
        'chamber_of_commerce_number' => '',
        'counterparty_address' => [
                
        ],
        'counterparty_alias' => [
                
        ],
        'created' => '',
        'description' => '',
        'external_url' => '',
        'group' => [
                [
                                'instance_description' => '',
                                'item' => [
                                                                [
                                                                                                                                'billing_date' => '',
                                                                                                                                'id' => 0,
                                                                                                                                'quantity' => 0,
                                                                                                                                'total_vat_exclusive' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'total_vat_inclusive' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'type_description' => '',
                                                                                                                                'type_description_translated' => '',
                                                                                                                                'unit_vat_exclusive' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'unit_vat_inclusive' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'vat' => 0
                                                                ]
                                ],
                                'product_vat_exclusive' => [
                                                                
                                ],
                                'product_vat_inclusive' => [
                                                                
                                ],
                                'type' => '',
                                'type_description' => '',
                                'type_description_translated' => ''
                ]
        ],
        'id' => 0,
        'invoice_date' => '',
        'invoice_number' => '',
        'request_reference_split_the_bill' => [
                [
                                'id' => 0,
                                'type' => ''
                ]
        ],
        'status' => '',
        'total_vat' => [
                
        ],
        'total_vat_exclusive' => [
                
        ],
        'total_vat_inclusive' => [
                
        ],
        'updated' => '',
        'vat_number' => ''
    ],
    'DraftPayment' => [
        'entries' => [
                [
                                'alias' => [
                                                                
                                ],
                                'amount' => [
                                                                
                                ],
                                'attachment' => [
                                                                [
                                                                                                                                'id' => 0,
                                                                                                                                'monetary_account_id' => 0
                                                                ]
                                ],
                                'counterparty_alias' => [
                                                                
                                ],
                                'description' => '',
                                'id' => 0,
                                'merchant_reference' => '',
                                'type' => ''
                ]
        ],
        'number_of_required_accepts' => 0,
        'previous_updated_timestamp' => '',
        'schedule' => [
                'object' => [
                                'Payment' => [
                                                                'address_billing' => [
                                                                                                                                
                                                                ],
                                                                'address_shipping' => [
                                                                                                                                
                                                                ],
                                                                'alias' => [
                                                                                                                                
                                                                ],
                                                                'allow_bunqto' => null,
                                                                'amount' => [
                                                                                                                                
                                                                ],
                                                                'attachment' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'balance_after_mutation' => [
                                                                                                                                
                                                                ],
                                                                'batch_id' => 0,
                                                                'bunqto_expiry' => '',
                                                                'bunqto_share_url' => '',
                                                                'bunqto_status' => '',
                                                                'bunqto_sub_status' => '',
                                                                'bunqto_time_responded' => '',
                                                                'counterparty_alias' => [
                                                                                                                                
                                                                ],
                                                                'created' => '',
                                                                'description' => '',
                                                                'geolocation' => [
                                                                                                                                
                                                                ],
                                                                'id' => 0,
                                                                'merchant_reference' => '',
                                                                'monetary_account_id' => 0,
                                                                'payment_auto_allocate_instance' => [
                                                                                                                                'created' => '',
                                                                                                                                'error_message' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'id' => 0,
                                                                                                                                'payment_auto_allocate_id' => 0,
                                                                                                                                'payment_batch' => [
                                                                                                                                                                                                                                                                'payments' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'Payment' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'payment_id' => 0,
                                                                                                                                'status' => '',
                                                                                                                                'updated' => ''
                                                                ],
                                                                'request_reference_split_the_bill' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'scheduled_id' => 0,
                                                                'sub_type' => '',
                                                                'type' => '',
                                                                'updated' => ''
                                ],
                                'PaymentBatch' => [
                                                                
                                ]
                ],
                'recurrence_size' => 0,
                'recurrence_unit' => '',
                'status' => '',
                'time_end' => '',
                'time_start' => ''
        ],
        'status' => ''
    ],
    'MasterCardAction' => [
        'alias' => [
                
        ],
        'all_mastercard_action_refund' => [
                [
                                'additional_information' => [
                                                                'attachment' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'id' => 0
                                                                                                                                ]
                                                                ],
                                                                'category' => '',
                                                                'comment' => '',
                                                                'reason' => '',
                                                                'terms_and_conditions' => ''
                                ],
                                'alias' => [
                                                                
                                ],
                                'amount' => [
                                                                
                                ],
                                'attachment' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'category' => '',
                                'comment' => '',
                                'counterparty_alias' => [
                                                                
                                ],
                                'created' => '',
                                'description' => '',
                                'id' => 0,
                                'label_card' => [
                                                                'expiry_date' => '',
                                                                'label_user' => [
                                                                                                                                
                                                                ],
                                                                'second_line' => '',
                                                                'status' => '',
                                                                'type' => '',
                                                                'uuid' => ''
                                ],
                                'label_user_creator' => [
                                                                
                                ],
                                'mastercard_action_id' => 0,
                                'reason' => '',
                                'reference_mastercard_action_event' => [
                                                                [
                                                                                                                                'event_id' => 0
                                                                ]
                                ],
                                'status' => '',
                                'status_description' => '',
                                'status_description_translated' => '',
                                'status_together_url' => '',
                                'sub_type' => '',
                                'terms_and_conditions' => '',
                                'time_refund' => '',
                                'type' => '',
                                'updated' => ''
                ]
        ],
        'amount_billing' => [
                
        ],
        'amount_converted' => [
                
        ],
        'amount_fee' => [
                
        ],
        'amount_local' => [
                
        ],
        'amount_original_billing' => [
                
        ],
        'amount_original_local' => [
                
        ],
        'applied_limit' => '',
        'authorisation_status' => '',
        'authorisation_type' => '',
        'card_authorisation_id_response' => '',
        'card_id' => 0,
        'city' => '',
        'clearing_expiry_time' => '',
        'clearing_status' => '',
        'counterparty_alias' => [
                
        ],
        'decision' => '',
        'decision_description' => '',
        'decision_description_translated' => '',
        'decision_together_url' => '',
        'description' => '',
        'eligible_whitelist_id' => 0,
        'id' => 0,
        'label_card' => [
                
        ],
        'maturity_date' => '',
        'monetary_account_id' => 0,
        'pan_entry_mode_user' => '',
        'payment_status' => '',
        'pos_card_holder_presence' => '',
        'pos_card_presence' => '',
        'request_reference_split_the_bill' => [
                [
                                
                ]
        ],
        'reservation_expiry_time' => '',
        'secure_code_id' => 0,
        'settlement_status' => '',
        'token_status' => '',
        'wallet_provider_id' => ''
    ],
    'Payment' => [
        
    ],
    'PaymentBatch' => [
        
    ],
    'RequestResponse' => [
        'address_billing' => [
                
        ],
        'address_shipping' => [
                
        ],
        'alias' => [
                
        ],
        'amount_inquired' => [
                
        ],
        'amount_responded' => [
                
        ],
        'attachment' => [
                [
                                'content_type' => '',
                                'description' => '',
                                'urls' => [
                                                                [
                                                                                                                                'type' => '',
                                                                                                                                'url' => ''
                                                                ]
                                ]
                ]
        ],
        'counterparty_alias' => [
                
        ],
        'created' => '',
        'credit_scheme_identifier' => '',
        'description' => '',
        'eligible_whitelist_id' => 0,
        'event_id' => 0,
        'geolocation' => [
                
        ],
        'id' => 0,
        'mandate_identifier' => '',
        'minimum_age' => 0,
        'monetary_account_id' => 0,
        'redirect_url' => '',
        'request_reference_split_the_bill' => [
                [
                                
                ]
        ],
        'require_address' => '',
        'status' => '',
        'sub_type' => '',
        'time_expiry' => '',
        'time_refund_requested' => '',
        'time_refunded' => '',
        'time_responded' => '',
        'type' => '',
        'updated' => '',
        'user_refund_requested' => [
                
        ]
    ],
    'ScheduleInstance' => [
        'error_message' => [
                
        ],
        'request_reference_split_the_bill' => [
                [
                                
                ]
        ],
        'result_object' => [
                'Payment' => [
                                
                ],
                'PaymentBatch' => [
                                
                ]
        ],
        'scheduled_object' => [
                
        ],
        'state' => '',
        'time_end' => '',
        'time_start' => ''
    ],
    'TransferwisePayment' => [
        'alias' => [
                
        ],
        'amount_source' => [
                
        ],
        'amount_target' => [
                
        ],
        'counterparty_alias' => [
                
        ],
        'monetary_account_id' => '',
        'pay_in_reference' => '',
        'quote' => [
                'amount_fee' => [
                                
                ],
                'amount_source' => [
                                
                ],
                'amount_target' => [
                                
                ],
                'created' => '',
                'currency_source' => '',
                'currency_target' => '',
                'id' => 0,
                'quote_id' => '',
                'rate' => '',
                'time_delivery_estimate' => '',
                'time_expiry' => '',
                'updated' => ''
        ],
        'rate' => '',
        'recipient_id' => '',
        'reference' => '',
        'status' => '',
        'status_transferwise' => '',
        'status_transferwise_issue' => '',
        'sub_status' => '',
        'time_delivery_estimate' => ''
    ],
    'WhitelistResult' => [
        'error_message' => [
                
        ],
        'id' => 0,
        'monetary_account_paying_id' => 0,
        'object' => [
                'draftPayment' => [
                                
                ],
                'id' => 0,
                'requestResponse' => [
                                
                ]
        ],
        'request_reference_split_the_bill' => [
                [
                                
                ]
        ],
        'status' => '',
        'sub_status' => '',
        'whitelist' => [
                
        ]
    ]
  ],
  'require_address' => '',
  'scheduled_id' => 0,
  'status' => '',
  'time_expiry' => '',
  'time_responded' => '',
  'updated' => '',
  'user_alias_created' => [
    
  ],
  'user_alias_revoked' => [
    
  ],
  'want_tip' => null
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "address_billing": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_shipping": {},
  "allow_amount_higher": false,
  "allow_amount_lower": false,
  "allow_bunqme": false,
  "amount_inquired": {
    "currency": "",
    "value": ""
  },
  "amount_responded": {},
  "attachment": [
    {
      "id": 0
    }
  ],
  "batch_id": 0,
  "bunqme_share_url": "",
  "counterparty_alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "created": "",
  "description": "",
  "event_id": 0,
  "geolocation": {
    "altitude": 0,
    "latitude": 0,
    "longitude": 0,
    "radius": 0
  },
  "id": 0,
  "merchant_reference": "",
  "minimum_age": 0,
  "monetary_account_id": 0,
  "redirect_url": "",
  "reference_split_the_bill": {
    "BillingInvoice": {
      "address": {},
      "alias": {},
      "category": "",
      "chamber_of_commerce_number": "",
      "counterparty_address": {},
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "external_url": "",
      "group": [
        {
          "instance_description": "",
          "item": [
            {
              "billing_date": "",
              "id": 0,
              "quantity": 0,
              "total_vat_exclusive": {},
              "total_vat_inclusive": {},
              "type_description": "",
              "type_description_translated": "",
              "unit_vat_exclusive": {},
              "unit_vat_inclusive": {},
              "vat": 0
            }
          ],
          "product_vat_exclusive": {},
          "product_vat_inclusive": {},
          "type": "",
          "type_description": "",
          "type_description_translated": ""
        }
      ],
      "id": 0,
      "invoice_date": "",
      "invoice_number": "",
      "request_reference_split_the_bill": [
        {
          "id": 0,
          "type": ""
        }
      ],
      "status": "",
      "total_vat": {},
      "total_vat_exclusive": {},
      "total_vat_inclusive": {},
      "updated": "",
      "vat_number": ""
    },
    "DraftPayment": {
      "entries": [
        {
          "alias": {},
          "amount": {},
          "attachment": [
            {
              "id": 0,
              "monetary_account_id": 0
            }
          ],
          "counterparty_alias": {},
          "description": "",
          "id": 0,
          "merchant_reference": "",
          "type": ""
        }
      ],
      "number_of_required_accepts": 0,
      "previous_updated_timestamp": "",
      "schedule": {
        "object": {
          "Payment": {
            "address_billing": {},
            "address_shipping": {},
            "alias": {},
            "allow_bunqto": false,
            "amount": {},
            "attachment": [
              {}
            ],
            "balance_after_mutation": {},
            "batch_id": 0,
            "bunqto_expiry": "",
            "bunqto_share_url": "",
            "bunqto_status": "",
            "bunqto_sub_status": "",
            "bunqto_time_responded": "",
            "counterparty_alias": {},
            "created": "",
            "description": "",
            "geolocation": {},
            "id": 0,
            "merchant_reference": "",
            "monetary_account_id": 0,
            "payment_auto_allocate_instance": {
              "created": "",
              "error_message": [],
              "id": 0,
              "payment_auto_allocate_id": 0,
              "payment_batch": {
                "payments": {
                  "Payment": []
                }
              },
              "payment_id": 0,
              "status": "",
              "updated": ""
            },
            "request_reference_split_the_bill": [
              {}
            ],
            "scheduled_id": 0,
            "sub_type": "",
            "type": "",
            "updated": ""
          },
          "PaymentBatch": {}
        },
        "recurrence_size": 0,
        "recurrence_unit": "",
        "status": "",
        "time_end": "",
        "time_start": ""
      },
      "status": ""
    },
    "MasterCardAction": {
      "alias": {},
      "all_mastercard_action_refund": [
        {
          "additional_information": {
            "attachment": [
              {
                "id": 0
              }
            ],
            "category": "",
            "comment": "",
            "reason": "",
            "terms_and_conditions": ""
          },
          "alias": {},
          "amount": {},
          "attachment": [
            {}
          ],
          "category": "",
          "comment": "",
          "counterparty_alias": {},
          "created": "",
          "description": "",
          "id": 0,
          "label_card": {
            "expiry_date": "",
            "label_user": {},
            "second_line": "",
            "status": "",
            "type": "",
            "uuid": ""
          },
          "label_user_creator": {},
          "mastercard_action_id": 0,
          "reason": "",
          "reference_mastercard_action_event": [
            {
              "event_id": 0
            }
          ],
          "status": "",
          "status_description": "",
          "status_description_translated": "",
          "status_together_url": "",
          "sub_type": "",
          "terms_and_conditions": "",
          "time_refund": "",
          "type": "",
          "updated": ""
        }
      ],
      "amount_billing": {},
      "amount_converted": {},
      "amount_fee": {},
      "amount_local": {},
      "amount_original_billing": {},
      "amount_original_local": {},
      "applied_limit": "",
      "authorisation_status": "",
      "authorisation_type": "",
      "card_authorisation_id_response": "",
      "card_id": 0,
      "city": "",
      "clearing_expiry_time": "",
      "clearing_status": "",
      "counterparty_alias": {},
      "decision": "",
      "decision_description": "",
      "decision_description_translated": "",
      "decision_together_url": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "id": 0,
      "label_card": {},
      "maturity_date": "",
      "monetary_account_id": 0,
      "pan_entry_mode_user": "",
      "payment_status": "",
      "pos_card_holder_presence": "",
      "pos_card_presence": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "reservation_expiry_time": "",
      "secure_code_id": 0,
      "settlement_status": "",
      "token_status": "",
      "wallet_provider_id": ""
    },
    "Payment": {},
    "PaymentBatch": {},
    "RequestResponse": {
      "address_billing": {},
      "address_shipping": {},
      "alias": {},
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "content_type": "",
          "description": "",
          "urls": [
            {
              "type": "",
              "url": ""
            }
          ]
        }
      ],
      "counterparty_alias": {},
      "created": "",
      "credit_scheme_identifier": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "mandate_identifier": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "require_address": "",
      "status": "",
      "sub_type": "",
      "time_expiry": "",
      "time_refund_requested": "",
      "time_refunded": "",
      "time_responded": "",
      "type": "",
      "updated": "",
      "user_refund_requested": {}
    },
    "ScheduleInstance": {
      "error_message": [],
      "request_reference_split_the_bill": [
        {}
      ],
      "result_object": {
        "Payment": {},
        "PaymentBatch": {}
      },
      "scheduled_object": {},
      "state": "",
      "time_end": "",
      "time_start": ""
    },
    "TransferwisePayment": {
      "alias": {},
      "amount_source": {},
      "amount_target": {},
      "counterparty_alias": {},
      "monetary_account_id": "",
      "pay_in_reference": "",
      "quote": {
        "amount_fee": {},
        "amount_source": {},
        "amount_target": {},
        "created": "",
        "currency_source": "",
        "currency_target": "",
        "id": 0,
        "quote_id": "",
        "rate": "",
        "time_delivery_estimate": "",
        "time_expiry": "",
        "updated": ""
      },
      "rate": "",
      "recipient_id": "",
      "reference": "",
      "status": "",
      "status_transferwise": "",
      "status_transferwise_issue": "",
      "sub_status": "",
      "time_delivery_estimate": ""
    },
    "WhitelistResult": {
      "error_message": [],
      "id": 0,
      "monetary_account_paying_id": 0,
      "object": {
        "draftPayment": {},
        "id": 0,
        "requestResponse": {}
      },
      "request_reference_split_the_bill": [
        {}
      ],
      "status": "",
      "sub_status": "",
      "whitelist": {}
    }
  },
  "require_address": "",
  "scheduled_id": 0,
  "status": "",
  "time_expiry": "",
  "time_responded": "",
  "updated": "",
  "user_alias_created": {},
  "user_alias_revoked": {},
  "want_tip": false
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "address_billing": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_shipping": {},
  "allow_amount_higher": false,
  "allow_amount_lower": false,
  "allow_bunqme": false,
  "amount_inquired": {
    "currency": "",
    "value": ""
  },
  "amount_responded": {},
  "attachment": [
    {
      "id": 0
    }
  ],
  "batch_id": 0,
  "bunqme_share_url": "",
  "counterparty_alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "created": "",
  "description": "",
  "event_id": 0,
  "geolocation": {
    "altitude": 0,
    "latitude": 0,
    "longitude": 0,
    "radius": 0
  },
  "id": 0,
  "merchant_reference": "",
  "minimum_age": 0,
  "monetary_account_id": 0,
  "redirect_url": "",
  "reference_split_the_bill": {
    "BillingInvoice": {
      "address": {},
      "alias": {},
      "category": "",
      "chamber_of_commerce_number": "",
      "counterparty_address": {},
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "external_url": "",
      "group": [
        {
          "instance_description": "",
          "item": [
            {
              "billing_date": "",
              "id": 0,
              "quantity": 0,
              "total_vat_exclusive": {},
              "total_vat_inclusive": {},
              "type_description": "",
              "type_description_translated": "",
              "unit_vat_exclusive": {},
              "unit_vat_inclusive": {},
              "vat": 0
            }
          ],
          "product_vat_exclusive": {},
          "product_vat_inclusive": {},
          "type": "",
          "type_description": "",
          "type_description_translated": ""
        }
      ],
      "id": 0,
      "invoice_date": "",
      "invoice_number": "",
      "request_reference_split_the_bill": [
        {
          "id": 0,
          "type": ""
        }
      ],
      "status": "",
      "total_vat": {},
      "total_vat_exclusive": {},
      "total_vat_inclusive": {},
      "updated": "",
      "vat_number": ""
    },
    "DraftPayment": {
      "entries": [
        {
          "alias": {},
          "amount": {},
          "attachment": [
            {
              "id": 0,
              "monetary_account_id": 0
            }
          ],
          "counterparty_alias": {},
          "description": "",
          "id": 0,
          "merchant_reference": "",
          "type": ""
        }
      ],
      "number_of_required_accepts": 0,
      "previous_updated_timestamp": "",
      "schedule": {
        "object": {
          "Payment": {
            "address_billing": {},
            "address_shipping": {},
            "alias": {},
            "allow_bunqto": false,
            "amount": {},
            "attachment": [
              {}
            ],
            "balance_after_mutation": {},
            "batch_id": 0,
            "bunqto_expiry": "",
            "bunqto_share_url": "",
            "bunqto_status": "",
            "bunqto_sub_status": "",
            "bunqto_time_responded": "",
            "counterparty_alias": {},
            "created": "",
            "description": "",
            "geolocation": {},
            "id": 0,
            "merchant_reference": "",
            "monetary_account_id": 0,
            "payment_auto_allocate_instance": {
              "created": "",
              "error_message": [],
              "id": 0,
              "payment_auto_allocate_id": 0,
              "payment_batch": {
                "payments": {
                  "Payment": []
                }
              },
              "payment_id": 0,
              "status": "",
              "updated": ""
            },
            "request_reference_split_the_bill": [
              {}
            ],
            "scheduled_id": 0,
            "sub_type": "",
            "type": "",
            "updated": ""
          },
          "PaymentBatch": {}
        },
        "recurrence_size": 0,
        "recurrence_unit": "",
        "status": "",
        "time_end": "",
        "time_start": ""
      },
      "status": ""
    },
    "MasterCardAction": {
      "alias": {},
      "all_mastercard_action_refund": [
        {
          "additional_information": {
            "attachment": [
              {
                "id": 0
              }
            ],
            "category": "",
            "comment": "",
            "reason": "",
            "terms_and_conditions": ""
          },
          "alias": {},
          "amount": {},
          "attachment": [
            {}
          ],
          "category": "",
          "comment": "",
          "counterparty_alias": {},
          "created": "",
          "description": "",
          "id": 0,
          "label_card": {
            "expiry_date": "",
            "label_user": {},
            "second_line": "",
            "status": "",
            "type": "",
            "uuid": ""
          },
          "label_user_creator": {},
          "mastercard_action_id": 0,
          "reason": "",
          "reference_mastercard_action_event": [
            {
              "event_id": 0
            }
          ],
          "status": "",
          "status_description": "",
          "status_description_translated": "",
          "status_together_url": "",
          "sub_type": "",
          "terms_and_conditions": "",
          "time_refund": "",
          "type": "",
          "updated": ""
        }
      ],
      "amount_billing": {},
      "amount_converted": {},
      "amount_fee": {},
      "amount_local": {},
      "amount_original_billing": {},
      "amount_original_local": {},
      "applied_limit": "",
      "authorisation_status": "",
      "authorisation_type": "",
      "card_authorisation_id_response": "",
      "card_id": 0,
      "city": "",
      "clearing_expiry_time": "",
      "clearing_status": "",
      "counterparty_alias": {},
      "decision": "",
      "decision_description": "",
      "decision_description_translated": "",
      "decision_together_url": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "id": 0,
      "label_card": {},
      "maturity_date": "",
      "monetary_account_id": 0,
      "pan_entry_mode_user": "",
      "payment_status": "",
      "pos_card_holder_presence": "",
      "pos_card_presence": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "reservation_expiry_time": "",
      "secure_code_id": 0,
      "settlement_status": "",
      "token_status": "",
      "wallet_provider_id": ""
    },
    "Payment": {},
    "PaymentBatch": {},
    "RequestResponse": {
      "address_billing": {},
      "address_shipping": {},
      "alias": {},
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "content_type": "",
          "description": "",
          "urls": [
            {
              "type": "",
              "url": ""
            }
          ]
        }
      ],
      "counterparty_alias": {},
      "created": "",
      "credit_scheme_identifier": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "mandate_identifier": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "require_address": "",
      "status": "",
      "sub_type": "",
      "time_expiry": "",
      "time_refund_requested": "",
      "time_refunded": "",
      "time_responded": "",
      "type": "",
      "updated": "",
      "user_refund_requested": {}
    },
    "ScheduleInstance": {
      "error_message": [],
      "request_reference_split_the_bill": [
        {}
      ],
      "result_object": {
        "Payment": {},
        "PaymentBatch": {}
      },
      "scheduled_object": {},
      "state": "",
      "time_end": "",
      "time_start": ""
    },
    "TransferwisePayment": {
      "alias": {},
      "amount_source": {},
      "amount_target": {},
      "counterparty_alias": {},
      "monetary_account_id": "",
      "pay_in_reference": "",
      "quote": {
        "amount_fee": {},
        "amount_source": {},
        "amount_target": {},
        "created": "",
        "currency_source": "",
        "currency_target": "",
        "id": 0,
        "quote_id": "",
        "rate": "",
        "time_delivery_estimate": "",
        "time_expiry": "",
        "updated": ""
      },
      "rate": "",
      "recipient_id": "",
      "reference": "",
      "status": "",
      "status_transferwise": "",
      "status_transferwise_issue": "",
      "sub_status": "",
      "time_delivery_estimate": ""
    },
    "WhitelistResult": {
      "error_message": [],
      "id": 0,
      "monetary_account_paying_id": 0,
      "object": {
        "draftPayment": {},
        "id": 0,
        "requestResponse": {}
      },
      "request_reference_split_the_bill": [
        {}
      ],
      "status": "",
      "sub_status": "",
      "whitelist": {}
    }
  },
  "require_address": "",
  "scheduled_id": 0,
  "status": "",
  "time_expiry": "",
  "time_responded": "",
  "updated": "",
  "user_alias_created": {},
  "user_alias_revoked": {},
  "want_tip": false
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"allow_amount_higher\": false,\n  \"allow_amount_lower\": false,\n  \"allow_bunqme\": false,\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"id\": 0\n    }\n  ],\n  \"batch_id\": 0,\n  \"bunqme_share_url\": \"\",\n  \"counterparty_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {},\n      \"alias\": {},\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {},\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {},\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"require_address\": \"\",\n  \"scheduled_id\": 0,\n  \"status\": \"\",\n  \"time_expiry\": \"\",\n  \"time_responded\": \"\",\n  \"updated\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {},\n  \"want_tip\": false\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId"

payload = {
    "address_billing": {
        "city": "",
        "country": "",
        "extra": "",
        "house_number": "",
        "is_user_address_updated": False,
        "mailbox_name": "",
        "po_box": "",
        "postal_code": "",
        "province": "",
        "street": ""
    },
    "address_shipping": {},
    "allow_amount_higher": False,
    "allow_amount_lower": False,
    "allow_bunqme": False,
    "amount_inquired": {
        "currency": "",
        "value": ""
    },
    "amount_responded": {},
    "attachment": [{ "id": 0 }],
    "batch_id": 0,
    "bunqme_share_url": "",
    "counterparty_alias": {
        "avatar": {
            "anchor_uuid": "",
            "image": [
                {
                    "attachment_public_uuid": "",
                    "content_type": "",
                    "height": 0,
                    "width": 0
                }
            ],
            "style": "",
            "uuid": ""
        },
        "bunq_me": {
            "name": "",
            "service": "",
            "type": "",
            "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": False,
        "label_user": {
            "avatar": {},
            "country": "",
            "display_name": "",
            "public_nick_name": "",
            "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
    },
    "created": "",
    "description": "",
    "event_id": 0,
    "geolocation": {
        "altitude": 0,
        "latitude": 0,
        "longitude": 0,
        "radius": 0
    },
    "id": 0,
    "merchant_reference": "",
    "minimum_age": 0,
    "monetary_account_id": 0,
    "redirect_url": "",
    "reference_split_the_bill": {
        "BillingInvoice": {
            "address": {},
            "alias": {},
            "category": "",
            "chamber_of_commerce_number": "",
            "counterparty_address": {},
            "counterparty_alias": {},
            "created": "",
            "description": "",
            "external_url": "",
            "group": [
                {
                    "instance_description": "",
                    "item": [
                        {
                            "billing_date": "",
                            "id": 0,
                            "quantity": 0,
                            "total_vat_exclusive": {},
                            "total_vat_inclusive": {},
                            "type_description": "",
                            "type_description_translated": "",
                            "unit_vat_exclusive": {},
                            "unit_vat_inclusive": {},
                            "vat": 0
                        }
                    ],
                    "product_vat_exclusive": {},
                    "product_vat_inclusive": {},
                    "type": "",
                    "type_description": "",
                    "type_description_translated": ""
                }
            ],
            "id": 0,
            "invoice_date": "",
            "invoice_number": "",
            "request_reference_split_the_bill": [
                {
                    "id": 0,
                    "type": ""
                }
            ],
            "status": "",
            "total_vat": {},
            "total_vat_exclusive": {},
            "total_vat_inclusive": {},
            "updated": "",
            "vat_number": ""
        },
        "DraftPayment": {
            "entries": [
                {
                    "alias": {},
                    "amount": {},
                    "attachment": [
                        {
                            "id": 0,
                            "monetary_account_id": 0
                        }
                    ],
                    "counterparty_alias": {},
                    "description": "",
                    "id": 0,
                    "merchant_reference": "",
                    "type": ""
                }
            ],
            "number_of_required_accepts": 0,
            "previous_updated_timestamp": "",
            "schedule": {
                "object": {
                    "Payment": {
                        "address_billing": {},
                        "address_shipping": {},
                        "alias": {},
                        "allow_bunqto": False,
                        "amount": {},
                        "attachment": [{}],
                        "balance_after_mutation": {},
                        "batch_id": 0,
                        "bunqto_expiry": "",
                        "bunqto_share_url": "",
                        "bunqto_status": "",
                        "bunqto_sub_status": "",
                        "bunqto_time_responded": "",
                        "counterparty_alias": {},
                        "created": "",
                        "description": "",
                        "geolocation": {},
                        "id": 0,
                        "merchant_reference": "",
                        "monetary_account_id": 0,
                        "payment_auto_allocate_instance": {
                            "created": "",
                            "error_message": [],
                            "id": 0,
                            "payment_auto_allocate_id": 0,
                            "payment_batch": { "payments": { "Payment": [] } },
                            "payment_id": 0,
                            "status": "",
                            "updated": ""
                        },
                        "request_reference_split_the_bill": [{}],
                        "scheduled_id": 0,
                        "sub_type": "",
                        "type": "",
                        "updated": ""
                    },
                    "PaymentBatch": {}
                },
                "recurrence_size": 0,
                "recurrence_unit": "",
                "status": "",
                "time_end": "",
                "time_start": ""
            },
            "status": ""
        },
        "MasterCardAction": {
            "alias": {},
            "all_mastercard_action_refund": [
                {
                    "additional_information": {
                        "attachment": [{ "id": 0 }],
                        "category": "",
                        "comment": "",
                        "reason": "",
                        "terms_and_conditions": ""
                    },
                    "alias": {},
                    "amount": {},
                    "attachment": [{}],
                    "category": "",
                    "comment": "",
                    "counterparty_alias": {},
                    "created": "",
                    "description": "",
                    "id": 0,
                    "label_card": {
                        "expiry_date": "",
                        "label_user": {},
                        "second_line": "",
                        "status": "",
                        "type": "",
                        "uuid": ""
                    },
                    "label_user_creator": {},
                    "mastercard_action_id": 0,
                    "reason": "",
                    "reference_mastercard_action_event": [{ "event_id": 0 }],
                    "status": "",
                    "status_description": "",
                    "status_description_translated": "",
                    "status_together_url": "",
                    "sub_type": "",
                    "terms_and_conditions": "",
                    "time_refund": "",
                    "type": "",
                    "updated": ""
                }
            ],
            "amount_billing": {},
            "amount_converted": {},
            "amount_fee": {},
            "amount_local": {},
            "amount_original_billing": {},
            "amount_original_local": {},
            "applied_limit": "",
            "authorisation_status": "",
            "authorisation_type": "",
            "card_authorisation_id_response": "",
            "card_id": 0,
            "city": "",
            "clearing_expiry_time": "",
            "clearing_status": "",
            "counterparty_alias": {},
            "decision": "",
            "decision_description": "",
            "decision_description_translated": "",
            "decision_together_url": "",
            "description": "",
            "eligible_whitelist_id": 0,
            "id": 0,
            "label_card": {},
            "maturity_date": "",
            "monetary_account_id": 0,
            "pan_entry_mode_user": "",
            "payment_status": "",
            "pos_card_holder_presence": "",
            "pos_card_presence": "",
            "request_reference_split_the_bill": [{}],
            "reservation_expiry_time": "",
            "secure_code_id": 0,
            "settlement_status": "",
            "token_status": "",
            "wallet_provider_id": ""
        },
        "Payment": {},
        "PaymentBatch": {},
        "RequestResponse": {
            "address_billing": {},
            "address_shipping": {},
            "alias": {},
            "amount_inquired": {},
            "amount_responded": {},
            "attachment": [
                {
                    "content_type": "",
                    "description": "",
                    "urls": [
                        {
                            "type": "",
                            "url": ""
                        }
                    ]
                }
            ],
            "counterparty_alias": {},
            "created": "",
            "credit_scheme_identifier": "",
            "description": "",
            "eligible_whitelist_id": 0,
            "event_id": 0,
            "geolocation": {},
            "id": 0,
            "mandate_identifier": "",
            "minimum_age": 0,
            "monetary_account_id": 0,
            "redirect_url": "",
            "request_reference_split_the_bill": [{}],
            "require_address": "",
            "status": "",
            "sub_type": "",
            "time_expiry": "",
            "time_refund_requested": "",
            "time_refunded": "",
            "time_responded": "",
            "type": "",
            "updated": "",
            "user_refund_requested": {}
        },
        "ScheduleInstance": {
            "error_message": [],
            "request_reference_split_the_bill": [{}],
            "result_object": {
                "Payment": {},
                "PaymentBatch": {}
            },
            "scheduled_object": {},
            "state": "",
            "time_end": "",
            "time_start": ""
        },
        "TransferwisePayment": {
            "alias": {},
            "amount_source": {},
            "amount_target": {},
            "counterparty_alias": {},
            "monetary_account_id": "",
            "pay_in_reference": "",
            "quote": {
                "amount_fee": {},
                "amount_source": {},
                "amount_target": {},
                "created": "",
                "currency_source": "",
                "currency_target": "",
                "id": 0,
                "quote_id": "",
                "rate": "",
                "time_delivery_estimate": "",
                "time_expiry": "",
                "updated": ""
            },
            "rate": "",
            "recipient_id": "",
            "reference": "",
            "status": "",
            "status_transferwise": "",
            "status_transferwise_issue": "",
            "sub_status": "",
            "time_delivery_estimate": ""
        },
        "WhitelistResult": {
            "error_message": [],
            "id": 0,
            "monetary_account_paying_id": 0,
            "object": {
                "draftPayment": {},
                "id": 0,
                "requestResponse": {}
            },
            "request_reference_split_the_bill": [{}],
            "status": "",
            "sub_status": "",
            "whitelist": {}
        }
    },
    "require_address": "",
    "scheduled_id": 0,
    "status": "",
    "time_expiry": "",
    "time_responded": "",
    "updated": "",
    "user_alias_created": {},
    "user_alias_revoked": {},
    "want_tip": False
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId"

payload <- "{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"allow_amount_higher\": false,\n  \"allow_amount_lower\": false,\n  \"allow_bunqme\": false,\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"id\": 0\n    }\n  ],\n  \"batch_id\": 0,\n  \"bunqme_share_url\": \"\",\n  \"counterparty_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {},\n      \"alias\": {},\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {},\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {},\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"require_address\": \"\",\n  \"scheduled_id\": 0,\n  \"status\": \"\",\n  \"time_expiry\": \"\",\n  \"time_responded\": \"\",\n  \"updated\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {},\n  \"want_tip\": false\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"allow_amount_higher\": false,\n  \"allow_amount_lower\": false,\n  \"allow_bunqme\": false,\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"id\": 0\n    }\n  ],\n  \"batch_id\": 0,\n  \"bunqme_share_url\": \"\",\n  \"counterparty_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {},\n      \"alias\": {},\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {},\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {},\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"require_address\": \"\",\n  \"scheduled_id\": 0,\n  \"status\": \"\",\n  \"time_expiry\": \"\",\n  \"time_responded\": \"\",\n  \"updated\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {},\n  \"want_tip\": false\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"allow_amount_higher\": false,\n  \"allow_amount_lower\": false,\n  \"allow_bunqme\": false,\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"id\": 0\n    }\n  ],\n  \"batch_id\": 0,\n  \"bunqme_share_url\": \"\",\n  \"counterparty_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"merchant_reference\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {},\n      \"alias\": {},\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {},\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {},\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"require_address\": \"\",\n  \"scheduled_id\": 0,\n  \"status\": \"\",\n  \"time_expiry\": \"\",\n  \"time_responded\": \"\",\n  \"updated\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {},\n  \"want_tip\": false\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId";

    let payload = json!({
        "address_billing": json!({
            "city": "",
            "country": "",
            "extra": "",
            "house_number": "",
            "is_user_address_updated": false,
            "mailbox_name": "",
            "po_box": "",
            "postal_code": "",
            "province": "",
            "street": ""
        }),
        "address_shipping": json!({}),
        "allow_amount_higher": false,
        "allow_amount_lower": false,
        "allow_bunqme": false,
        "amount_inquired": json!({
            "currency": "",
            "value": ""
        }),
        "amount_responded": json!({}),
        "attachment": (json!({"id": 0})),
        "batch_id": 0,
        "bunqme_share_url": "",
        "counterparty_alias": json!({
            "avatar": json!({
                "anchor_uuid": "",
                "image": (
                    json!({
                        "attachment_public_uuid": "",
                        "content_type": "",
                        "height": 0,
                        "width": 0
                    })
                ),
                "style": "",
                "uuid": ""
            }),
            "bunq_me": json!({
                "name": "",
                "service": "",
                "type": "",
                "value": ""
            }),
            "country": "",
            "display_name": "",
            "iban": "",
            "is_light": false,
            "label_user": json!({
                "avatar": json!({}),
                "country": "",
                "display_name": "",
                "public_nick_name": "",
                "uuid": ""
            }),
            "merchant_category_code": "",
            "swift_account_number": "",
            "swift_bic": "",
            "transferwise_account_number": "",
            "transferwise_bank_code": ""
        }),
        "created": "",
        "description": "",
        "event_id": 0,
        "geolocation": json!({
            "altitude": 0,
            "latitude": 0,
            "longitude": 0,
            "radius": 0
        }),
        "id": 0,
        "merchant_reference": "",
        "minimum_age": 0,
        "monetary_account_id": 0,
        "redirect_url": "",
        "reference_split_the_bill": json!({
            "BillingInvoice": json!({
                "address": json!({}),
                "alias": json!({}),
                "category": "",
                "chamber_of_commerce_number": "",
                "counterparty_address": json!({}),
                "counterparty_alias": json!({}),
                "created": "",
                "description": "",
                "external_url": "",
                "group": (
                    json!({
                        "instance_description": "",
                        "item": (
                            json!({
                                "billing_date": "",
                                "id": 0,
                                "quantity": 0,
                                "total_vat_exclusive": json!({}),
                                "total_vat_inclusive": json!({}),
                                "type_description": "",
                                "type_description_translated": "",
                                "unit_vat_exclusive": json!({}),
                                "unit_vat_inclusive": json!({}),
                                "vat": 0
                            })
                        ),
                        "product_vat_exclusive": json!({}),
                        "product_vat_inclusive": json!({}),
                        "type": "",
                        "type_description": "",
                        "type_description_translated": ""
                    })
                ),
                "id": 0,
                "invoice_date": "",
                "invoice_number": "",
                "request_reference_split_the_bill": (
                    json!({
                        "id": 0,
                        "type": ""
                    })
                ),
                "status": "",
                "total_vat": json!({}),
                "total_vat_exclusive": json!({}),
                "total_vat_inclusive": json!({}),
                "updated": "",
                "vat_number": ""
            }),
            "DraftPayment": json!({
                "entries": (
                    json!({
                        "alias": json!({}),
                        "amount": json!({}),
                        "attachment": (
                            json!({
                                "id": 0,
                                "monetary_account_id": 0
                            })
                        ),
                        "counterparty_alias": json!({}),
                        "description": "",
                        "id": 0,
                        "merchant_reference": "",
                        "type": ""
                    })
                ),
                "number_of_required_accepts": 0,
                "previous_updated_timestamp": "",
                "schedule": json!({
                    "object": json!({
                        "Payment": json!({
                            "address_billing": json!({}),
                            "address_shipping": json!({}),
                            "alias": json!({}),
                            "allow_bunqto": false,
                            "amount": json!({}),
                            "attachment": (json!({})),
                            "balance_after_mutation": json!({}),
                            "batch_id": 0,
                            "bunqto_expiry": "",
                            "bunqto_share_url": "",
                            "bunqto_status": "",
                            "bunqto_sub_status": "",
                            "bunqto_time_responded": "",
                            "counterparty_alias": json!({}),
                            "created": "",
                            "description": "",
                            "geolocation": json!({}),
                            "id": 0,
                            "merchant_reference": "",
                            "monetary_account_id": 0,
                            "payment_auto_allocate_instance": json!({
                                "created": "",
                                "error_message": (),
                                "id": 0,
                                "payment_auto_allocate_id": 0,
                                "payment_batch": json!({"payments": json!({"Payment": ()})}),
                                "payment_id": 0,
                                "status": "",
                                "updated": ""
                            }),
                            "request_reference_split_the_bill": (json!({})),
                            "scheduled_id": 0,
                            "sub_type": "",
                            "type": "",
                            "updated": ""
                        }),
                        "PaymentBatch": json!({})
                    }),
                    "recurrence_size": 0,
                    "recurrence_unit": "",
                    "status": "",
                    "time_end": "",
                    "time_start": ""
                }),
                "status": ""
            }),
            "MasterCardAction": json!({
                "alias": json!({}),
                "all_mastercard_action_refund": (
                    json!({
                        "additional_information": json!({
                            "attachment": (json!({"id": 0})),
                            "category": "",
                            "comment": "",
                            "reason": "",
                            "terms_and_conditions": ""
                        }),
                        "alias": json!({}),
                        "amount": json!({}),
                        "attachment": (json!({})),
                        "category": "",
                        "comment": "",
                        "counterparty_alias": json!({}),
                        "created": "",
                        "description": "",
                        "id": 0,
                        "label_card": json!({
                            "expiry_date": "",
                            "label_user": json!({}),
                            "second_line": "",
                            "status": "",
                            "type": "",
                            "uuid": ""
                        }),
                        "label_user_creator": json!({}),
                        "mastercard_action_id": 0,
                        "reason": "",
                        "reference_mastercard_action_event": (json!({"event_id": 0})),
                        "status": "",
                        "status_description": "",
                        "status_description_translated": "",
                        "status_together_url": "",
                        "sub_type": "",
                        "terms_and_conditions": "",
                        "time_refund": "",
                        "type": "",
                        "updated": ""
                    })
                ),
                "amount_billing": json!({}),
                "amount_converted": json!({}),
                "amount_fee": json!({}),
                "amount_local": json!({}),
                "amount_original_billing": json!({}),
                "amount_original_local": json!({}),
                "applied_limit": "",
                "authorisation_status": "",
                "authorisation_type": "",
                "card_authorisation_id_response": "",
                "card_id": 0,
                "city": "",
                "clearing_expiry_time": "",
                "clearing_status": "",
                "counterparty_alias": json!({}),
                "decision": "",
                "decision_description": "",
                "decision_description_translated": "",
                "decision_together_url": "",
                "description": "",
                "eligible_whitelist_id": 0,
                "id": 0,
                "label_card": json!({}),
                "maturity_date": "",
                "monetary_account_id": 0,
                "pan_entry_mode_user": "",
                "payment_status": "",
                "pos_card_holder_presence": "",
                "pos_card_presence": "",
                "request_reference_split_the_bill": (json!({})),
                "reservation_expiry_time": "",
                "secure_code_id": 0,
                "settlement_status": "",
                "token_status": "",
                "wallet_provider_id": ""
            }),
            "Payment": json!({}),
            "PaymentBatch": json!({}),
            "RequestResponse": json!({
                "address_billing": json!({}),
                "address_shipping": json!({}),
                "alias": json!({}),
                "amount_inquired": json!({}),
                "amount_responded": json!({}),
                "attachment": (
                    json!({
                        "content_type": "",
                        "description": "",
                        "urls": (
                            json!({
                                "type": "",
                                "url": ""
                            })
                        )
                    })
                ),
                "counterparty_alias": json!({}),
                "created": "",
                "credit_scheme_identifier": "",
                "description": "",
                "eligible_whitelist_id": 0,
                "event_id": 0,
                "geolocation": json!({}),
                "id": 0,
                "mandate_identifier": "",
                "minimum_age": 0,
                "monetary_account_id": 0,
                "redirect_url": "",
                "request_reference_split_the_bill": (json!({})),
                "require_address": "",
                "status": "",
                "sub_type": "",
                "time_expiry": "",
                "time_refund_requested": "",
                "time_refunded": "",
                "time_responded": "",
                "type": "",
                "updated": "",
                "user_refund_requested": json!({})
            }),
            "ScheduleInstance": json!({
                "error_message": (),
                "request_reference_split_the_bill": (json!({})),
                "result_object": json!({
                    "Payment": json!({}),
                    "PaymentBatch": json!({})
                }),
                "scheduled_object": json!({}),
                "state": "",
                "time_end": "",
                "time_start": ""
            }),
            "TransferwisePayment": json!({
                "alias": json!({}),
                "amount_source": json!({}),
                "amount_target": json!({}),
                "counterparty_alias": json!({}),
                "monetary_account_id": "",
                "pay_in_reference": "",
                "quote": json!({
                    "amount_fee": json!({}),
                    "amount_source": json!({}),
                    "amount_target": json!({}),
                    "created": "",
                    "currency_source": "",
                    "currency_target": "",
                    "id": 0,
                    "quote_id": "",
                    "rate": "",
                    "time_delivery_estimate": "",
                    "time_expiry": "",
                    "updated": ""
                }),
                "rate": "",
                "recipient_id": "",
                "reference": "",
                "status": "",
                "status_transferwise": "",
                "status_transferwise_issue": "",
                "sub_status": "",
                "time_delivery_estimate": ""
            }),
            "WhitelistResult": json!({
                "error_message": (),
                "id": 0,
                "monetary_account_paying_id": 0,
                "object": json!({
                    "draftPayment": json!({}),
                    "id": 0,
                    "requestResponse": json!({})
                }),
                "request_reference_split_the_bill": (json!({})),
                "status": "",
                "sub_status": "",
                "whitelist": json!({})
            })
        }),
        "require_address": "",
        "scheduled_id": 0,
        "status": "",
        "time_expiry": "",
        "time_responded": "",
        "updated": "",
        "user_alias_created": json!({}),
        "user_alias_revoked": json!({}),
        "want_tip": false
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "address_billing": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_shipping": {},
  "allow_amount_higher": false,
  "allow_amount_lower": false,
  "allow_bunqme": false,
  "amount_inquired": {
    "currency": "",
    "value": ""
  },
  "amount_responded": {},
  "attachment": [
    {
      "id": 0
    }
  ],
  "batch_id": 0,
  "bunqme_share_url": "",
  "counterparty_alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "created": "",
  "description": "",
  "event_id": 0,
  "geolocation": {
    "altitude": 0,
    "latitude": 0,
    "longitude": 0,
    "radius": 0
  },
  "id": 0,
  "merchant_reference": "",
  "minimum_age": 0,
  "monetary_account_id": 0,
  "redirect_url": "",
  "reference_split_the_bill": {
    "BillingInvoice": {
      "address": {},
      "alias": {},
      "category": "",
      "chamber_of_commerce_number": "",
      "counterparty_address": {},
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "external_url": "",
      "group": [
        {
          "instance_description": "",
          "item": [
            {
              "billing_date": "",
              "id": 0,
              "quantity": 0,
              "total_vat_exclusive": {},
              "total_vat_inclusive": {},
              "type_description": "",
              "type_description_translated": "",
              "unit_vat_exclusive": {},
              "unit_vat_inclusive": {},
              "vat": 0
            }
          ],
          "product_vat_exclusive": {},
          "product_vat_inclusive": {},
          "type": "",
          "type_description": "",
          "type_description_translated": ""
        }
      ],
      "id": 0,
      "invoice_date": "",
      "invoice_number": "",
      "request_reference_split_the_bill": [
        {
          "id": 0,
          "type": ""
        }
      ],
      "status": "",
      "total_vat": {},
      "total_vat_exclusive": {},
      "total_vat_inclusive": {},
      "updated": "",
      "vat_number": ""
    },
    "DraftPayment": {
      "entries": [
        {
          "alias": {},
          "amount": {},
          "attachment": [
            {
              "id": 0,
              "monetary_account_id": 0
            }
          ],
          "counterparty_alias": {},
          "description": "",
          "id": 0,
          "merchant_reference": "",
          "type": ""
        }
      ],
      "number_of_required_accepts": 0,
      "previous_updated_timestamp": "",
      "schedule": {
        "object": {
          "Payment": {
            "address_billing": {},
            "address_shipping": {},
            "alias": {},
            "allow_bunqto": false,
            "amount": {},
            "attachment": [
              {}
            ],
            "balance_after_mutation": {},
            "batch_id": 0,
            "bunqto_expiry": "",
            "bunqto_share_url": "",
            "bunqto_status": "",
            "bunqto_sub_status": "",
            "bunqto_time_responded": "",
            "counterparty_alias": {},
            "created": "",
            "description": "",
            "geolocation": {},
            "id": 0,
            "merchant_reference": "",
            "monetary_account_id": 0,
            "payment_auto_allocate_instance": {
              "created": "",
              "error_message": [],
              "id": 0,
              "payment_auto_allocate_id": 0,
              "payment_batch": {
                "payments": {
                  "Payment": []
                }
              },
              "payment_id": 0,
              "status": "",
              "updated": ""
            },
            "request_reference_split_the_bill": [
              {}
            ],
            "scheduled_id": 0,
            "sub_type": "",
            "type": "",
            "updated": ""
          },
          "PaymentBatch": {}
        },
        "recurrence_size": 0,
        "recurrence_unit": "",
        "status": "",
        "time_end": "",
        "time_start": ""
      },
      "status": ""
    },
    "MasterCardAction": {
      "alias": {},
      "all_mastercard_action_refund": [
        {
          "additional_information": {
            "attachment": [
              {
                "id": 0
              }
            ],
            "category": "",
            "comment": "",
            "reason": "",
            "terms_and_conditions": ""
          },
          "alias": {},
          "amount": {},
          "attachment": [
            {}
          ],
          "category": "",
          "comment": "",
          "counterparty_alias": {},
          "created": "",
          "description": "",
          "id": 0,
          "label_card": {
            "expiry_date": "",
            "label_user": {},
            "second_line": "",
            "status": "",
            "type": "",
            "uuid": ""
          },
          "label_user_creator": {},
          "mastercard_action_id": 0,
          "reason": "",
          "reference_mastercard_action_event": [
            {
              "event_id": 0
            }
          ],
          "status": "",
          "status_description": "",
          "status_description_translated": "",
          "status_together_url": "",
          "sub_type": "",
          "terms_and_conditions": "",
          "time_refund": "",
          "type": "",
          "updated": ""
        }
      ],
      "amount_billing": {},
      "amount_converted": {},
      "amount_fee": {},
      "amount_local": {},
      "amount_original_billing": {},
      "amount_original_local": {},
      "applied_limit": "",
      "authorisation_status": "",
      "authorisation_type": "",
      "card_authorisation_id_response": "",
      "card_id": 0,
      "city": "",
      "clearing_expiry_time": "",
      "clearing_status": "",
      "counterparty_alias": {},
      "decision": "",
      "decision_description": "",
      "decision_description_translated": "",
      "decision_together_url": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "id": 0,
      "label_card": {},
      "maturity_date": "",
      "monetary_account_id": 0,
      "pan_entry_mode_user": "",
      "payment_status": "",
      "pos_card_holder_presence": "",
      "pos_card_presence": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "reservation_expiry_time": "",
      "secure_code_id": 0,
      "settlement_status": "",
      "token_status": "",
      "wallet_provider_id": ""
    },
    "Payment": {},
    "PaymentBatch": {},
    "RequestResponse": {
      "address_billing": {},
      "address_shipping": {},
      "alias": {},
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "content_type": "",
          "description": "",
          "urls": [
            {
              "type": "",
              "url": ""
            }
          ]
        }
      ],
      "counterparty_alias": {},
      "created": "",
      "credit_scheme_identifier": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "mandate_identifier": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "require_address": "",
      "status": "",
      "sub_type": "",
      "time_expiry": "",
      "time_refund_requested": "",
      "time_refunded": "",
      "time_responded": "",
      "type": "",
      "updated": "",
      "user_refund_requested": {}
    },
    "ScheduleInstance": {
      "error_message": [],
      "request_reference_split_the_bill": [
        {}
      ],
      "result_object": {
        "Payment": {},
        "PaymentBatch": {}
      },
      "scheduled_object": {},
      "state": "",
      "time_end": "",
      "time_start": ""
    },
    "TransferwisePayment": {
      "alias": {},
      "amount_source": {},
      "amount_target": {},
      "counterparty_alias": {},
      "monetary_account_id": "",
      "pay_in_reference": "",
      "quote": {
        "amount_fee": {},
        "amount_source": {},
        "amount_target": {},
        "created": "",
        "currency_source": "",
        "currency_target": "",
        "id": 0,
        "quote_id": "",
        "rate": "",
        "time_delivery_estimate": "",
        "time_expiry": "",
        "updated": ""
      },
      "rate": "",
      "recipient_id": "",
      "reference": "",
      "status": "",
      "status_transferwise": "",
      "status_transferwise_issue": "",
      "sub_status": "",
      "time_delivery_estimate": ""
    },
    "WhitelistResult": {
      "error_message": [],
      "id": 0,
      "monetary_account_paying_id": 0,
      "object": {
        "draftPayment": {},
        "id": 0,
        "requestResponse": {}
      },
      "request_reference_split_the_bill": [
        {}
      ],
      "status": "",
      "sub_status": "",
      "whitelist": {}
    }
  },
  "require_address": "",
  "scheduled_id": 0,
  "status": "",
  "time_expiry": "",
  "time_responded": "",
  "updated": "",
  "user_alias_created": {},
  "user_alias_revoked": {},
  "want_tip": false
}'
echo '{
  "address_billing": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_shipping": {},
  "allow_amount_higher": false,
  "allow_amount_lower": false,
  "allow_bunqme": false,
  "amount_inquired": {
    "currency": "",
    "value": ""
  },
  "amount_responded": {},
  "attachment": [
    {
      "id": 0
    }
  ],
  "batch_id": 0,
  "bunqme_share_url": "",
  "counterparty_alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "created": "",
  "description": "",
  "event_id": 0,
  "geolocation": {
    "altitude": 0,
    "latitude": 0,
    "longitude": 0,
    "radius": 0
  },
  "id": 0,
  "merchant_reference": "",
  "minimum_age": 0,
  "monetary_account_id": 0,
  "redirect_url": "",
  "reference_split_the_bill": {
    "BillingInvoice": {
      "address": {},
      "alias": {},
      "category": "",
      "chamber_of_commerce_number": "",
      "counterparty_address": {},
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "external_url": "",
      "group": [
        {
          "instance_description": "",
          "item": [
            {
              "billing_date": "",
              "id": 0,
              "quantity": 0,
              "total_vat_exclusive": {},
              "total_vat_inclusive": {},
              "type_description": "",
              "type_description_translated": "",
              "unit_vat_exclusive": {},
              "unit_vat_inclusive": {},
              "vat": 0
            }
          ],
          "product_vat_exclusive": {},
          "product_vat_inclusive": {},
          "type": "",
          "type_description": "",
          "type_description_translated": ""
        }
      ],
      "id": 0,
      "invoice_date": "",
      "invoice_number": "",
      "request_reference_split_the_bill": [
        {
          "id": 0,
          "type": ""
        }
      ],
      "status": "",
      "total_vat": {},
      "total_vat_exclusive": {},
      "total_vat_inclusive": {},
      "updated": "",
      "vat_number": ""
    },
    "DraftPayment": {
      "entries": [
        {
          "alias": {},
          "amount": {},
          "attachment": [
            {
              "id": 0,
              "monetary_account_id": 0
            }
          ],
          "counterparty_alias": {},
          "description": "",
          "id": 0,
          "merchant_reference": "",
          "type": ""
        }
      ],
      "number_of_required_accepts": 0,
      "previous_updated_timestamp": "",
      "schedule": {
        "object": {
          "Payment": {
            "address_billing": {},
            "address_shipping": {},
            "alias": {},
            "allow_bunqto": false,
            "amount": {},
            "attachment": [
              {}
            ],
            "balance_after_mutation": {},
            "batch_id": 0,
            "bunqto_expiry": "",
            "bunqto_share_url": "",
            "bunqto_status": "",
            "bunqto_sub_status": "",
            "bunqto_time_responded": "",
            "counterparty_alias": {},
            "created": "",
            "description": "",
            "geolocation": {},
            "id": 0,
            "merchant_reference": "",
            "monetary_account_id": 0,
            "payment_auto_allocate_instance": {
              "created": "",
              "error_message": [],
              "id": 0,
              "payment_auto_allocate_id": 0,
              "payment_batch": {
                "payments": {
                  "Payment": []
                }
              },
              "payment_id": 0,
              "status": "",
              "updated": ""
            },
            "request_reference_split_the_bill": [
              {}
            ],
            "scheduled_id": 0,
            "sub_type": "",
            "type": "",
            "updated": ""
          },
          "PaymentBatch": {}
        },
        "recurrence_size": 0,
        "recurrence_unit": "",
        "status": "",
        "time_end": "",
        "time_start": ""
      },
      "status": ""
    },
    "MasterCardAction": {
      "alias": {},
      "all_mastercard_action_refund": [
        {
          "additional_information": {
            "attachment": [
              {
                "id": 0
              }
            ],
            "category": "",
            "comment": "",
            "reason": "",
            "terms_and_conditions": ""
          },
          "alias": {},
          "amount": {},
          "attachment": [
            {}
          ],
          "category": "",
          "comment": "",
          "counterparty_alias": {},
          "created": "",
          "description": "",
          "id": 0,
          "label_card": {
            "expiry_date": "",
            "label_user": {},
            "second_line": "",
            "status": "",
            "type": "",
            "uuid": ""
          },
          "label_user_creator": {},
          "mastercard_action_id": 0,
          "reason": "",
          "reference_mastercard_action_event": [
            {
              "event_id": 0
            }
          ],
          "status": "",
          "status_description": "",
          "status_description_translated": "",
          "status_together_url": "",
          "sub_type": "",
          "terms_and_conditions": "",
          "time_refund": "",
          "type": "",
          "updated": ""
        }
      ],
      "amount_billing": {},
      "amount_converted": {},
      "amount_fee": {},
      "amount_local": {},
      "amount_original_billing": {},
      "amount_original_local": {},
      "applied_limit": "",
      "authorisation_status": "",
      "authorisation_type": "",
      "card_authorisation_id_response": "",
      "card_id": 0,
      "city": "",
      "clearing_expiry_time": "",
      "clearing_status": "",
      "counterparty_alias": {},
      "decision": "",
      "decision_description": "",
      "decision_description_translated": "",
      "decision_together_url": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "id": 0,
      "label_card": {},
      "maturity_date": "",
      "monetary_account_id": 0,
      "pan_entry_mode_user": "",
      "payment_status": "",
      "pos_card_holder_presence": "",
      "pos_card_presence": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "reservation_expiry_time": "",
      "secure_code_id": 0,
      "settlement_status": "",
      "token_status": "",
      "wallet_provider_id": ""
    },
    "Payment": {},
    "PaymentBatch": {},
    "RequestResponse": {
      "address_billing": {},
      "address_shipping": {},
      "alias": {},
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "content_type": "",
          "description": "",
          "urls": [
            {
              "type": "",
              "url": ""
            }
          ]
        }
      ],
      "counterparty_alias": {},
      "created": "",
      "credit_scheme_identifier": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "mandate_identifier": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "require_address": "",
      "status": "",
      "sub_type": "",
      "time_expiry": "",
      "time_refund_requested": "",
      "time_refunded": "",
      "time_responded": "",
      "type": "",
      "updated": "",
      "user_refund_requested": {}
    },
    "ScheduleInstance": {
      "error_message": [],
      "request_reference_split_the_bill": [
        {}
      ],
      "result_object": {
        "Payment": {},
        "PaymentBatch": {}
      },
      "scheduled_object": {},
      "state": "",
      "time_end": "",
      "time_start": ""
    },
    "TransferwisePayment": {
      "alias": {},
      "amount_source": {},
      "amount_target": {},
      "counterparty_alias": {},
      "monetary_account_id": "",
      "pay_in_reference": "",
      "quote": {
        "amount_fee": {},
        "amount_source": {},
        "amount_target": {},
        "created": "",
        "currency_source": "",
        "currency_target": "",
        "id": 0,
        "quote_id": "",
        "rate": "",
        "time_delivery_estimate": "",
        "time_expiry": "",
        "updated": ""
      },
      "rate": "",
      "recipient_id": "",
      "reference": "",
      "status": "",
      "status_transferwise": "",
      "status_transferwise_issue": "",
      "sub_status": "",
      "time_delivery_estimate": ""
    },
    "WhitelistResult": {
      "error_message": [],
      "id": 0,
      "monetary_account_paying_id": 0,
      "object": {
        "draftPayment": {},
        "id": 0,
        "requestResponse": {}
      },
      "request_reference_split_the_bill": [
        {}
      ],
      "status": "",
      "sub_status": "",
      "whitelist": {}
    }
  },
  "require_address": "",
  "scheduled_id": 0,
  "status": "",
  "time_expiry": "",
  "time_responded": "",
  "updated": "",
  "user_alias_created": {},
  "user_alias_revoked": {},
  "want_tip": false
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "address_billing": {\n    "city": "",\n    "country": "",\n    "extra": "",\n    "house_number": "",\n    "is_user_address_updated": false,\n    "mailbox_name": "",\n    "po_box": "",\n    "postal_code": "",\n    "province": "",\n    "street": ""\n  },\n  "address_shipping": {},\n  "allow_amount_higher": false,\n  "allow_amount_lower": false,\n  "allow_bunqme": false,\n  "amount_inquired": {\n    "currency": "",\n    "value": ""\n  },\n  "amount_responded": {},\n  "attachment": [\n    {\n      "id": 0\n    }\n  ],\n  "batch_id": 0,\n  "bunqme_share_url": "",\n  "counterparty_alias": {\n    "avatar": {\n      "anchor_uuid": "",\n      "image": [\n        {\n          "attachment_public_uuid": "",\n          "content_type": "",\n          "height": 0,\n          "width": 0\n        }\n      ],\n      "style": "",\n      "uuid": ""\n    },\n    "bunq_me": {\n      "name": "",\n      "service": "",\n      "type": "",\n      "value": ""\n    },\n    "country": "",\n    "display_name": "",\n    "iban": "",\n    "is_light": false,\n    "label_user": {\n      "avatar": {},\n      "country": "",\n      "display_name": "",\n      "public_nick_name": "",\n      "uuid": ""\n    },\n    "merchant_category_code": "",\n    "swift_account_number": "",\n    "swift_bic": "",\n    "transferwise_account_number": "",\n    "transferwise_bank_code": ""\n  },\n  "created": "",\n  "description": "",\n  "event_id": 0,\n  "geolocation": {\n    "altitude": 0,\n    "latitude": 0,\n    "longitude": 0,\n    "radius": 0\n  },\n  "id": 0,\n  "merchant_reference": "",\n  "minimum_age": 0,\n  "monetary_account_id": 0,\n  "redirect_url": "",\n  "reference_split_the_bill": {\n    "BillingInvoice": {\n      "address": {},\n      "alias": {},\n      "category": "",\n      "chamber_of_commerce_number": "",\n      "counterparty_address": {},\n      "counterparty_alias": {},\n      "created": "",\n      "description": "",\n      "external_url": "",\n      "group": [\n        {\n          "instance_description": "",\n          "item": [\n            {\n              "billing_date": "",\n              "id": 0,\n              "quantity": 0,\n              "total_vat_exclusive": {},\n              "total_vat_inclusive": {},\n              "type_description": "",\n              "type_description_translated": "",\n              "unit_vat_exclusive": {},\n              "unit_vat_inclusive": {},\n              "vat": 0\n            }\n          ],\n          "product_vat_exclusive": {},\n          "product_vat_inclusive": {},\n          "type": "",\n          "type_description": "",\n          "type_description_translated": ""\n        }\n      ],\n      "id": 0,\n      "invoice_date": "",\n      "invoice_number": "",\n      "request_reference_split_the_bill": [\n        {\n          "id": 0,\n          "type": ""\n        }\n      ],\n      "status": "",\n      "total_vat": {},\n      "total_vat_exclusive": {},\n      "total_vat_inclusive": {},\n      "updated": "",\n      "vat_number": ""\n    },\n    "DraftPayment": {\n      "entries": [\n        {\n          "alias": {},\n          "amount": {},\n          "attachment": [\n            {\n              "id": 0,\n              "monetary_account_id": 0\n            }\n          ],\n          "counterparty_alias": {},\n          "description": "",\n          "id": 0,\n          "merchant_reference": "",\n          "type": ""\n        }\n      ],\n      "number_of_required_accepts": 0,\n      "previous_updated_timestamp": "",\n      "schedule": {\n        "object": {\n          "Payment": {\n            "address_billing": {},\n            "address_shipping": {},\n            "alias": {},\n            "allow_bunqto": false,\n            "amount": {},\n            "attachment": [\n              {}\n            ],\n            "balance_after_mutation": {},\n            "batch_id": 0,\n            "bunqto_expiry": "",\n            "bunqto_share_url": "",\n            "bunqto_status": "",\n            "bunqto_sub_status": "",\n            "bunqto_time_responded": "",\n            "counterparty_alias": {},\n            "created": "",\n            "description": "",\n            "geolocation": {},\n            "id": 0,\n            "merchant_reference": "",\n            "monetary_account_id": 0,\n            "payment_auto_allocate_instance": {\n              "created": "",\n              "error_message": [],\n              "id": 0,\n              "payment_auto_allocate_id": 0,\n              "payment_batch": {\n                "payments": {\n                  "Payment": []\n                }\n              },\n              "payment_id": 0,\n              "status": "",\n              "updated": ""\n            },\n            "request_reference_split_the_bill": [\n              {}\n            ],\n            "scheduled_id": 0,\n            "sub_type": "",\n            "type": "",\n            "updated": ""\n          },\n          "PaymentBatch": {}\n        },\n        "recurrence_size": 0,\n        "recurrence_unit": "",\n        "status": "",\n        "time_end": "",\n        "time_start": ""\n      },\n      "status": ""\n    },\n    "MasterCardAction": {\n      "alias": {},\n      "all_mastercard_action_refund": [\n        {\n          "additional_information": {\n            "attachment": [\n              {\n                "id": 0\n              }\n            ],\n            "category": "",\n            "comment": "",\n            "reason": "",\n            "terms_and_conditions": ""\n          },\n          "alias": {},\n          "amount": {},\n          "attachment": [\n            {}\n          ],\n          "category": "",\n          "comment": "",\n          "counterparty_alias": {},\n          "created": "",\n          "description": "",\n          "id": 0,\n          "label_card": {\n            "expiry_date": "",\n            "label_user": {},\n            "second_line": "",\n            "status": "",\n            "type": "",\n            "uuid": ""\n          },\n          "label_user_creator": {},\n          "mastercard_action_id": 0,\n          "reason": "",\n          "reference_mastercard_action_event": [\n            {\n              "event_id": 0\n            }\n          ],\n          "status": "",\n          "status_description": "",\n          "status_description_translated": "",\n          "status_together_url": "",\n          "sub_type": "",\n          "terms_and_conditions": "",\n          "time_refund": "",\n          "type": "",\n          "updated": ""\n        }\n      ],\n      "amount_billing": {},\n      "amount_converted": {},\n      "amount_fee": {},\n      "amount_local": {},\n      "amount_original_billing": {},\n      "amount_original_local": {},\n      "applied_limit": "",\n      "authorisation_status": "",\n      "authorisation_type": "",\n      "card_authorisation_id_response": "",\n      "card_id": 0,\n      "city": "",\n      "clearing_expiry_time": "",\n      "clearing_status": "",\n      "counterparty_alias": {},\n      "decision": "",\n      "decision_description": "",\n      "decision_description_translated": "",\n      "decision_together_url": "",\n      "description": "",\n      "eligible_whitelist_id": 0,\n      "id": 0,\n      "label_card": {},\n      "maturity_date": "",\n      "monetary_account_id": 0,\n      "pan_entry_mode_user": "",\n      "payment_status": "",\n      "pos_card_holder_presence": "",\n      "pos_card_presence": "",\n      "request_reference_split_the_bill": [\n        {}\n      ],\n      "reservation_expiry_time": "",\n      "secure_code_id": 0,\n      "settlement_status": "",\n      "token_status": "",\n      "wallet_provider_id": ""\n    },\n    "Payment": {},\n    "PaymentBatch": {},\n    "RequestResponse": {\n      "address_billing": {},\n      "address_shipping": {},\n      "alias": {},\n      "amount_inquired": {},\n      "amount_responded": {},\n      "attachment": [\n        {\n          "content_type": "",\n          "description": "",\n          "urls": [\n            {\n              "type": "",\n              "url": ""\n            }\n          ]\n        }\n      ],\n      "counterparty_alias": {},\n      "created": "",\n      "credit_scheme_identifier": "",\n      "description": "",\n      "eligible_whitelist_id": 0,\n      "event_id": 0,\n      "geolocation": {},\n      "id": 0,\n      "mandate_identifier": "",\n      "minimum_age": 0,\n      "monetary_account_id": 0,\n      "redirect_url": "",\n      "request_reference_split_the_bill": [\n        {}\n      ],\n      "require_address": "",\n      "status": "",\n      "sub_type": "",\n      "time_expiry": "",\n      "time_refund_requested": "",\n      "time_refunded": "",\n      "time_responded": "",\n      "type": "",\n      "updated": "",\n      "user_refund_requested": {}\n    },\n    "ScheduleInstance": {\n      "error_message": [],\n      "request_reference_split_the_bill": [\n        {}\n      ],\n      "result_object": {\n        "Payment": {},\n        "PaymentBatch": {}\n      },\n      "scheduled_object": {},\n      "state": "",\n      "time_end": "",\n      "time_start": ""\n    },\n    "TransferwisePayment": {\n      "alias": {},\n      "amount_source": {},\n      "amount_target": {},\n      "counterparty_alias": {},\n      "monetary_account_id": "",\n      "pay_in_reference": "",\n      "quote": {\n        "amount_fee": {},\n        "amount_source": {},\n        "amount_target": {},\n        "created": "",\n        "currency_source": "",\n        "currency_target": "",\n        "id": 0,\n        "quote_id": "",\n        "rate": "",\n        "time_delivery_estimate": "",\n        "time_expiry": "",\n        "updated": ""\n      },\n      "rate": "",\n      "recipient_id": "",\n      "reference": "",\n      "status": "",\n      "status_transferwise": "",\n      "status_transferwise_issue": "",\n      "sub_status": "",\n      "time_delivery_estimate": ""\n    },\n    "WhitelistResult": {\n      "error_message": [],\n      "id": 0,\n      "monetary_account_paying_id": 0,\n      "object": {\n        "draftPayment": {},\n        "id": 0,\n        "requestResponse": {}\n      },\n      "request_reference_split_the_bill": [\n        {}\n      ],\n      "status": "",\n      "sub_status": "",\n      "whitelist": {}\n    }\n  },\n  "require_address": "",\n  "scheduled_id": 0,\n  "status": "",\n  "time_expiry": "",\n  "time_responded": "",\n  "updated": "",\n  "user_alias_created": {},\n  "user_alias_revoked": {},\n  "want_tip": false\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "address_billing": [
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  ],
  "address_shipping": [],
  "allow_amount_higher": false,
  "allow_amount_lower": false,
  "allow_bunqme": false,
  "amount_inquired": [
    "currency": "",
    "value": ""
  ],
  "amount_responded": [],
  "attachment": [["id": 0]],
  "batch_id": 0,
  "bunqme_share_url": "",
  "counterparty_alias": [
    "avatar": [
      "anchor_uuid": "",
      "image": [
        [
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        ]
      ],
      "style": "",
      "uuid": ""
    ],
    "bunq_me": [
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    ],
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": [
      "avatar": [],
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    ],
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  ],
  "created": "",
  "description": "",
  "event_id": 0,
  "geolocation": [
    "altitude": 0,
    "latitude": 0,
    "longitude": 0,
    "radius": 0
  ],
  "id": 0,
  "merchant_reference": "",
  "minimum_age": 0,
  "monetary_account_id": 0,
  "redirect_url": "",
  "reference_split_the_bill": [
    "BillingInvoice": [
      "address": [],
      "alias": [],
      "category": "",
      "chamber_of_commerce_number": "",
      "counterparty_address": [],
      "counterparty_alias": [],
      "created": "",
      "description": "",
      "external_url": "",
      "group": [
        [
          "instance_description": "",
          "item": [
            [
              "billing_date": "",
              "id": 0,
              "quantity": 0,
              "total_vat_exclusive": [],
              "total_vat_inclusive": [],
              "type_description": "",
              "type_description_translated": "",
              "unit_vat_exclusive": [],
              "unit_vat_inclusive": [],
              "vat": 0
            ]
          ],
          "product_vat_exclusive": [],
          "product_vat_inclusive": [],
          "type": "",
          "type_description": "",
          "type_description_translated": ""
        ]
      ],
      "id": 0,
      "invoice_date": "",
      "invoice_number": "",
      "request_reference_split_the_bill": [
        [
          "id": 0,
          "type": ""
        ]
      ],
      "status": "",
      "total_vat": [],
      "total_vat_exclusive": [],
      "total_vat_inclusive": [],
      "updated": "",
      "vat_number": ""
    ],
    "DraftPayment": [
      "entries": [
        [
          "alias": [],
          "amount": [],
          "attachment": [
            [
              "id": 0,
              "monetary_account_id": 0
            ]
          ],
          "counterparty_alias": [],
          "description": "",
          "id": 0,
          "merchant_reference": "",
          "type": ""
        ]
      ],
      "number_of_required_accepts": 0,
      "previous_updated_timestamp": "",
      "schedule": [
        "object": [
          "Payment": [
            "address_billing": [],
            "address_shipping": [],
            "alias": [],
            "allow_bunqto": false,
            "amount": [],
            "attachment": [[]],
            "balance_after_mutation": [],
            "batch_id": 0,
            "bunqto_expiry": "",
            "bunqto_share_url": "",
            "bunqto_status": "",
            "bunqto_sub_status": "",
            "bunqto_time_responded": "",
            "counterparty_alias": [],
            "created": "",
            "description": "",
            "geolocation": [],
            "id": 0,
            "merchant_reference": "",
            "monetary_account_id": 0,
            "payment_auto_allocate_instance": [
              "created": "",
              "error_message": [],
              "id": 0,
              "payment_auto_allocate_id": 0,
              "payment_batch": ["payments": ["Payment": []]],
              "payment_id": 0,
              "status": "",
              "updated": ""
            ],
            "request_reference_split_the_bill": [[]],
            "scheduled_id": 0,
            "sub_type": "",
            "type": "",
            "updated": ""
          ],
          "PaymentBatch": []
        ],
        "recurrence_size": 0,
        "recurrence_unit": "",
        "status": "",
        "time_end": "",
        "time_start": ""
      ],
      "status": ""
    ],
    "MasterCardAction": [
      "alias": [],
      "all_mastercard_action_refund": [
        [
          "additional_information": [
            "attachment": [["id": 0]],
            "category": "",
            "comment": "",
            "reason": "",
            "terms_and_conditions": ""
          ],
          "alias": [],
          "amount": [],
          "attachment": [[]],
          "category": "",
          "comment": "",
          "counterparty_alias": [],
          "created": "",
          "description": "",
          "id": 0,
          "label_card": [
            "expiry_date": "",
            "label_user": [],
            "second_line": "",
            "status": "",
            "type": "",
            "uuid": ""
          ],
          "label_user_creator": [],
          "mastercard_action_id": 0,
          "reason": "",
          "reference_mastercard_action_event": [["event_id": 0]],
          "status": "",
          "status_description": "",
          "status_description_translated": "",
          "status_together_url": "",
          "sub_type": "",
          "terms_and_conditions": "",
          "time_refund": "",
          "type": "",
          "updated": ""
        ]
      ],
      "amount_billing": [],
      "amount_converted": [],
      "amount_fee": [],
      "amount_local": [],
      "amount_original_billing": [],
      "amount_original_local": [],
      "applied_limit": "",
      "authorisation_status": "",
      "authorisation_type": "",
      "card_authorisation_id_response": "",
      "card_id": 0,
      "city": "",
      "clearing_expiry_time": "",
      "clearing_status": "",
      "counterparty_alias": [],
      "decision": "",
      "decision_description": "",
      "decision_description_translated": "",
      "decision_together_url": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "id": 0,
      "label_card": [],
      "maturity_date": "",
      "monetary_account_id": 0,
      "pan_entry_mode_user": "",
      "payment_status": "",
      "pos_card_holder_presence": "",
      "pos_card_presence": "",
      "request_reference_split_the_bill": [[]],
      "reservation_expiry_time": "",
      "secure_code_id": 0,
      "settlement_status": "",
      "token_status": "",
      "wallet_provider_id": ""
    ],
    "Payment": [],
    "PaymentBatch": [],
    "RequestResponse": [
      "address_billing": [],
      "address_shipping": [],
      "alias": [],
      "amount_inquired": [],
      "amount_responded": [],
      "attachment": [
        [
          "content_type": "",
          "description": "",
          "urls": [
            [
              "type": "",
              "url": ""
            ]
          ]
        ]
      ],
      "counterparty_alias": [],
      "created": "",
      "credit_scheme_identifier": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "event_id": 0,
      "geolocation": [],
      "id": 0,
      "mandate_identifier": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "request_reference_split_the_bill": [[]],
      "require_address": "",
      "status": "",
      "sub_type": "",
      "time_expiry": "",
      "time_refund_requested": "",
      "time_refunded": "",
      "time_responded": "",
      "type": "",
      "updated": "",
      "user_refund_requested": []
    ],
    "ScheduleInstance": [
      "error_message": [],
      "request_reference_split_the_bill": [[]],
      "result_object": [
        "Payment": [],
        "PaymentBatch": []
      ],
      "scheduled_object": [],
      "state": "",
      "time_end": "",
      "time_start": ""
    ],
    "TransferwisePayment": [
      "alias": [],
      "amount_source": [],
      "amount_target": [],
      "counterparty_alias": [],
      "monetary_account_id": "",
      "pay_in_reference": "",
      "quote": [
        "amount_fee": [],
        "amount_source": [],
        "amount_target": [],
        "created": "",
        "currency_source": "",
        "currency_target": "",
        "id": 0,
        "quote_id": "",
        "rate": "",
        "time_delivery_estimate": "",
        "time_expiry": "",
        "updated": ""
      ],
      "rate": "",
      "recipient_id": "",
      "reference": "",
      "status": "",
      "status_transferwise": "",
      "status_transferwise_issue": "",
      "sub_status": "",
      "time_delivery_estimate": ""
    ],
    "WhitelistResult": [
      "error_message": [],
      "id": 0,
      "monetary_account_paying_id": 0,
      "object": [
        "draftPayment": [],
        "id": 0,
        "requestResponse": []
      ],
      "request_reference_split_the_bill": [[]],
      "status": "",
      "sub_status": "",
      "whitelist": []
    ]
  ],
  "require_address": "",
  "scheduled_id": 0,
  "status": "",
  "time_expiry": "",
  "time_responded": "",
  "updated": "",
  "user_alias_created": [],
  "user_alias_revoked": [],
  "want_tip": false
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_RequestInquiryBatch_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
BODY json

{
  "event_id": 0,
  "reference_split_the_bill": {
    "BillingInvoice": {
      "address": {
        "city": "",
        "country": "",
        "extra": "",
        "house_number": "",
        "is_user_address_updated": false,
        "mailbox_name": "",
        "po_box": "",
        "postal_code": "",
        "province": "",
        "street": ""
      },
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "category": "",
      "chamber_of_commerce_number": "",
      "counterparty_address": {},
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "external_url": "",
      "group": [
        {
          "instance_description": "",
          "item": [
            {
              "billing_date": "",
              "id": 0,
              "quantity": 0,
              "total_vat_exclusive": {
                "currency": "",
                "value": ""
              },
              "total_vat_inclusive": {},
              "type_description": "",
              "type_description_translated": "",
              "unit_vat_exclusive": {},
              "unit_vat_inclusive": {},
              "vat": 0
            }
          ],
          "product_vat_exclusive": {},
          "product_vat_inclusive": {},
          "type": "",
          "type_description": "",
          "type_description_translated": ""
        }
      ],
      "id": 0,
      "invoice_date": "",
      "invoice_number": "",
      "request_reference_split_the_bill": [
        {
          "id": 0,
          "type": ""
        }
      ],
      "status": "",
      "total_vat": {},
      "total_vat_exclusive": {},
      "total_vat_inclusive": {},
      "updated": "",
      "vat_number": ""
    },
    "DraftPayment": {
      "entries": [
        {
          "alias": {},
          "amount": {},
          "attachment": [
            {
              "id": 0,
              "monetary_account_id": 0
            }
          ],
          "counterparty_alias": {},
          "description": "",
          "id": 0,
          "merchant_reference": "",
          "type": ""
        }
      ],
      "number_of_required_accepts": 0,
      "previous_updated_timestamp": "",
      "schedule": {
        "object": {
          "Payment": {
            "address_billing": {},
            "address_shipping": {},
            "alias": {},
            "allow_bunqto": false,
            "amount": {},
            "attachment": [
              {}
            ],
            "balance_after_mutation": {},
            "batch_id": 0,
            "bunqto_expiry": "",
            "bunqto_share_url": "",
            "bunqto_status": "",
            "bunqto_sub_status": "",
            "bunqto_time_responded": "",
            "counterparty_alias": {},
            "created": "",
            "description": "",
            "geolocation": {
              "altitude": 0,
              "latitude": 0,
              "longitude": 0,
              "radius": 0
            },
            "id": 0,
            "merchant_reference": "",
            "monetary_account_id": 0,
            "payment_auto_allocate_instance": {
              "created": "",
              "error_message": [],
              "id": 0,
              "payment_auto_allocate_id": 0,
              "payment_batch": {
                "payments": {
                  "Payment": []
                }
              },
              "payment_id": 0,
              "status": "",
              "updated": ""
            },
            "request_reference_split_the_bill": [
              {}
            ],
            "scheduled_id": 0,
            "sub_type": "",
            "type": "",
            "updated": ""
          },
          "PaymentBatch": {}
        },
        "recurrence_size": 0,
        "recurrence_unit": "",
        "status": "",
        "time_end": "",
        "time_start": ""
      },
      "status": ""
    },
    "MasterCardAction": {
      "alias": {},
      "all_mastercard_action_refund": [
        {
          "additional_information": {
            "attachment": [
              {
                "id": 0
              }
            ],
            "category": "",
            "comment": "",
            "reason": "",
            "terms_and_conditions": ""
          },
          "alias": {},
          "amount": {},
          "attachment": [
            {}
          ],
          "category": "",
          "comment": "",
          "counterparty_alias": {},
          "created": "",
          "description": "",
          "id": 0,
          "label_card": {
            "expiry_date": "",
            "label_user": {},
            "second_line": "",
            "status": "",
            "type": "",
            "uuid": ""
          },
          "label_user_creator": {},
          "mastercard_action_id": 0,
          "reason": "",
          "reference_mastercard_action_event": [
            {
              "event_id": 0
            }
          ],
          "status": "",
          "status_description": "",
          "status_description_translated": "",
          "status_together_url": "",
          "sub_type": "",
          "terms_and_conditions": "",
          "time_refund": "",
          "type": "",
          "updated": ""
        }
      ],
      "amount_billing": {},
      "amount_converted": {},
      "amount_fee": {},
      "amount_local": {},
      "amount_original_billing": {},
      "amount_original_local": {},
      "applied_limit": "",
      "authorisation_status": "",
      "authorisation_type": "",
      "card_authorisation_id_response": "",
      "card_id": 0,
      "city": "",
      "clearing_expiry_time": "",
      "clearing_status": "",
      "counterparty_alias": {},
      "decision": "",
      "decision_description": "",
      "decision_description_translated": "",
      "decision_together_url": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "id": 0,
      "label_card": {},
      "maturity_date": "",
      "monetary_account_id": 0,
      "pan_entry_mode_user": "",
      "payment_status": "",
      "pos_card_holder_presence": "",
      "pos_card_presence": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "reservation_expiry_time": "",
      "secure_code_id": 0,
      "settlement_status": "",
      "token_status": "",
      "wallet_provider_id": ""
    },
    "Payment": {},
    "PaymentBatch": {},
    "RequestResponse": {
      "address_billing": {},
      "address_shipping": {},
      "alias": {},
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "content_type": "",
          "description": "",
          "urls": [
            {
              "type": "",
              "url": ""
            }
          ]
        }
      ],
      "counterparty_alias": {},
      "created": "",
      "credit_scheme_identifier": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "mandate_identifier": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "require_address": "",
      "status": "",
      "sub_type": "",
      "time_expiry": "",
      "time_refund_requested": "",
      "time_refunded": "",
      "time_responded": "",
      "type": "",
      "updated": "",
      "user_refund_requested": {}
    },
    "ScheduleInstance": {
      "error_message": [],
      "request_reference_split_the_bill": [
        {}
      ],
      "result_object": {
        "Payment": {},
        "PaymentBatch": {}
      },
      "scheduled_object": {},
      "state": "",
      "time_end": "",
      "time_start": ""
    },
    "TransferwisePayment": {
      "alias": {},
      "amount_source": {},
      "amount_target": {},
      "counterparty_alias": {},
      "monetary_account_id": "",
      "pay_in_reference": "",
      "quote": {
        "amount_fee": {},
        "amount_source": {},
        "amount_target": {},
        "created": "",
        "currency_source": "",
        "currency_target": "",
        "id": 0,
        "quote_id": "",
        "rate": "",
        "time_delivery_estimate": "",
        "time_expiry": "",
        "updated": ""
      },
      "rate": "",
      "recipient_id": "",
      "reference": "",
      "status": "",
      "status_transferwise": "",
      "status_transferwise_issue": "",
      "sub_status": "",
      "time_delivery_estimate": ""
    },
    "WhitelistResult": {
      "error_message": [],
      "id": 0,
      "monetary_account_paying_id": 0,
      "object": {
        "draftPayment": {},
        "id": 0,
        "requestResponse": {}
      },
      "request_reference_split_the_bill": [
        {}
      ],
      "status": "",
      "sub_status": "",
      "whitelist": {}
    }
  },
  "request_inquiries": [
    {
      "address_billing": {},
      "address_shipping": {},
      "allow_amount_higher": false,
      "allow_amount_lower": false,
      "allow_bunqme": false,
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "id": 0
        }
      ],
      "batch_id": 0,
      "bunqme_share_url": "",
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "merchant_reference": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "reference_split_the_bill": {},
      "require_address": "",
      "scheduled_id": 0,
      "status": "",
      "time_expiry": "",
      "time_responded": "",
      "updated": "",
      "user_alias_created": {},
      "user_alias_revoked": {},
      "want_tip": false
    }
  ],
  "status": "",
  "total_amount_inquired": {}
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"event_id\": 0,\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {\n                \"currency\": \"\",\n                \"value\": \"\"\n              },\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {\n              \"altitude\": 0,\n              \"latitude\": 0,\n              \"longitude\": 0,\n              \"radius\": 0\n            },\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"request_inquiries\": [\n    {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"allow_amount_higher\": false,\n      \"allow_amount_lower\": false,\n      \"allow_bunqme\": false,\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"id\": 0\n        }\n      ],\n      \"batch_id\": 0,\n      \"bunqme_share_url\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"reference_split_the_bill\": {},\n      \"require_address\": \"\",\n      \"scheduled_id\": 0,\n      \"status\": \"\",\n      \"time_expiry\": \"\",\n      \"time_responded\": \"\",\n      \"updated\": \"\",\n      \"user_alias_created\": {},\n      \"user_alias_revoked\": {},\n      \"want_tip\": false\n    }\n  ],\n  \"status\": \"\",\n  \"total_amount_inquired\": {}\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch" {:headers {:user-agent ""
                                                                                                                              :x-bunq-client-authentication ""}
                                                                                                                    :content-type :json
                                                                                                                    :form-params {:event_id 0
                                                                                                                                  :reference_split_the_bill {:BillingInvoice {:address {:city ""
                                                                                                                                                                                        :country ""
                                                                                                                                                                                        :extra ""
                                                                                                                                                                                        :house_number ""
                                                                                                                                                                                        :is_user_address_updated false
                                                                                                                                                                                        :mailbox_name ""
                                                                                                                                                                                        :po_box ""
                                                                                                                                                                                        :postal_code ""
                                                                                                                                                                                        :province ""
                                                                                                                                                                                        :street ""}
                                                                                                                                                                              :alias {:avatar {:anchor_uuid ""
                                                                                                                                                                                               :image [{:attachment_public_uuid ""
                                                                                                                                                                                                        :content_type ""
                                                                                                                                                                                                        :height 0
                                                                                                                                                                                                        :width 0}]
                                                                                                                                                                                               :style ""
                                                                                                                                                                                               :uuid ""}
                                                                                                                                                                                      :bunq_me {:name ""
                                                                                                                                                                                                :service ""
                                                                                                                                                                                                :type ""
                                                                                                                                                                                                :value ""}
                                                                                                                                                                                      :country ""
                                                                                                                                                                                      :display_name ""
                                                                                                                                                                                      :iban ""
                                                                                                                                                                                      :is_light false
                                                                                                                                                                                      :label_user {:avatar {}
                                                                                                                                                                                                   :country ""
                                                                                                                                                                                                   :display_name ""
                                                                                                                                                                                                   :public_nick_name ""
                                                                                                                                                                                                   :uuid ""}
                                                                                                                                                                                      :merchant_category_code ""
                                                                                                                                                                                      :swift_account_number ""
                                                                                                                                                                                      :swift_bic ""
                                                                                                                                                                                      :transferwise_account_number ""
                                                                                                                                                                                      :transferwise_bank_code ""}
                                                                                                                                                                              :category ""
                                                                                                                                                                              :chamber_of_commerce_number ""
                                                                                                                                                                              :counterparty_address {}
                                                                                                                                                                              :counterparty_alias {}
                                                                                                                                                                              :created ""
                                                                                                                                                                              :description ""
                                                                                                                                                                              :external_url ""
                                                                                                                                                                              :group [{:instance_description ""
                                                                                                                                                                                       :item [{:billing_date ""
                                                                                                                                                                                               :id 0
                                                                                                                                                                                               :quantity 0
                                                                                                                                                                                               :total_vat_exclusive {:currency ""
                                                                                                                                                                                                                     :value ""}
                                                                                                                                                                                               :total_vat_inclusive {}
                                                                                                                                                                                               :type_description ""
                                                                                                                                                                                               :type_description_translated ""
                                                                                                                                                                                               :unit_vat_exclusive {}
                                                                                                                                                                                               :unit_vat_inclusive {}
                                                                                                                                                                                               :vat 0}]
                                                                                                                                                                                       :product_vat_exclusive {}
                                                                                                                                                                                       :product_vat_inclusive {}
                                                                                                                                                                                       :type ""
                                                                                                                                                                                       :type_description ""
                                                                                                                                                                                       :type_description_translated ""}]
                                                                                                                                                                              :id 0
                                                                                                                                                                              :invoice_date ""
                                                                                                                                                                              :invoice_number ""
                                                                                                                                                                              :request_reference_split_the_bill [{:id 0
                                                                                                                                                                                                                  :type ""}]
                                                                                                                                                                              :status ""
                                                                                                                                                                              :total_vat {}
                                                                                                                                                                              :total_vat_exclusive {}
                                                                                                                                                                              :total_vat_inclusive {}
                                                                                                                                                                              :updated ""
                                                                                                                                                                              :vat_number ""}
                                                                                                                                                             :DraftPayment {:entries [{:alias {}
                                                                                                                                                                                       :amount {}
                                                                                                                                                                                       :attachment [{:id 0
                                                                                                                                                                                                     :monetary_account_id 0}]
                                                                                                                                                                                       :counterparty_alias {}
                                                                                                                                                                                       :description ""
                                                                                                                                                                                       :id 0
                                                                                                                                                                                       :merchant_reference ""
                                                                                                                                                                                       :type ""}]
                                                                                                                                                                            :number_of_required_accepts 0
                                                                                                                                                                            :previous_updated_timestamp ""
                                                                                                                                                                            :schedule {:object {:Payment {:address_billing {}
                                                                                                                                                                                                          :address_shipping {}
                                                                                                                                                                                                          :alias {}
                                                                                                                                                                                                          :allow_bunqto false
                                                                                                                                                                                                          :amount {}
                                                                                                                                                                                                          :attachment [{}]
                                                                                                                                                                                                          :balance_after_mutation {}
                                                                                                                                                                                                          :batch_id 0
                                                                                                                                                                                                          :bunqto_expiry ""
                                                                                                                                                                                                          :bunqto_share_url ""
                                                                                                                                                                                                          :bunqto_status ""
                                                                                                                                                                                                          :bunqto_sub_status ""
                                                                                                                                                                                                          :bunqto_time_responded ""
                                                                                                                                                                                                          :counterparty_alias {}
                                                                                                                                                                                                          :created ""
                                                                                                                                                                                                          :description ""
                                                                                                                                                                                                          :geolocation {:altitude 0
                                                                                                                                                                                                                        :latitude 0
                                                                                                                                                                                                                        :longitude 0
                                                                                                                                                                                                                        :radius 0}
                                                                                                                                                                                                          :id 0
                                                                                                                                                                                                          :merchant_reference ""
                                                                                                                                                                                                          :monetary_account_id 0
                                                                                                                                                                                                          :payment_auto_allocate_instance {:created ""
                                                                                                                                                                                                                                           :error_message []
                                                                                                                                                                                                                                           :id 0
                                                                                                                                                                                                                                           :payment_auto_allocate_id 0
                                                                                                                                                                                                                                           :payment_batch {:payments {:Payment []}}
                                                                                                                                                                                                                                           :payment_id 0
                                                                                                                                                                                                                                           :status ""
                                                                                                                                                                                                                                           :updated ""}
                                                                                                                                                                                                          :request_reference_split_the_bill [{}]
                                                                                                                                                                                                          :scheduled_id 0
                                                                                                                                                                                                          :sub_type ""
                                                                                                                                                                                                          :type ""
                                                                                                                                                                                                          :updated ""}
                                                                                                                                                                                                :PaymentBatch {}}
                                                                                                                                                                                       :recurrence_size 0
                                                                                                                                                                                       :recurrence_unit ""
                                                                                                                                                                                       :status ""
                                                                                                                                                                                       :time_end ""
                                                                                                                                                                                       :time_start ""}
                                                                                                                                                                            :status ""}
                                                                                                                                                             :MasterCardAction {:alias {}
                                                                                                                                                                                :all_mastercard_action_refund [{:additional_information {:attachment [{:id 0}]
                                                                                                                                                                                                                                         :category ""
                                                                                                                                                                                                                                         :comment ""
                                                                                                                                                                                                                                         :reason ""
                                                                                                                                                                                                                                         :terms_and_conditions ""}
                                                                                                                                                                                                                :alias {}
                                                                                                                                                                                                                :amount {}
                                                                                                                                                                                                                :attachment [{}]
                                                                                                                                                                                                                :category ""
                                                                                                                                                                                                                :comment ""
                                                                                                                                                                                                                :counterparty_alias {}
                                                                                                                                                                                                                :created ""
                                                                                                                                                                                                                :description ""
                                                                                                                                                                                                                :id 0
                                                                                                                                                                                                                :label_card {:expiry_date ""
                                                                                                                                                                                                                             :label_user {}
                                                                                                                                                                                                                             :second_line ""
                                                                                                                                                                                                                             :status ""
                                                                                                                                                                                                                             :type ""
                                                                                                                                                                                                                             :uuid ""}
                                                                                                                                                                                                                :label_user_creator {}
                                                                                                                                                                                                                :mastercard_action_id 0
                                                                                                                                                                                                                :reason ""
                                                                                                                                                                                                                :reference_mastercard_action_event [{:event_id 0}]
                                                                                                                                                                                                                :status ""
                                                                                                                                                                                                                :status_description ""
                                                                                                                                                                                                                :status_description_translated ""
                                                                                                                                                                                                                :status_together_url ""
                                                                                                                                                                                                                :sub_type ""
                                                                                                                                                                                                                :terms_and_conditions ""
                                                                                                                                                                                                                :time_refund ""
                                                                                                                                                                                                                :type ""
                                                                                                                                                                                                                :updated ""}]
                                                                                                                                                                                :amount_billing {}
                                                                                                                                                                                :amount_converted {}
                                                                                                                                                                                :amount_fee {}
                                                                                                                                                                                :amount_local {}
                                                                                                                                                                                :amount_original_billing {}
                                                                                                                                                                                :amount_original_local {}
                                                                                                                                                                                :applied_limit ""
                                                                                                                                                                                :authorisation_status ""
                                                                                                                                                                                :authorisation_type ""
                                                                                                                                                                                :card_authorisation_id_response ""
                                                                                                                                                                                :card_id 0
                                                                                                                                                                                :city ""
                                                                                                                                                                                :clearing_expiry_time ""
                                                                                                                                                                                :clearing_status ""
                                                                                                                                                                                :counterparty_alias {}
                                                                                                                                                                                :decision ""
                                                                                                                                                                                :decision_description ""
                                                                                                                                                                                :decision_description_translated ""
                                                                                                                                                                                :decision_together_url ""
                                                                                                                                                                                :description ""
                                                                                                                                                                                :eligible_whitelist_id 0
                                                                                                                                                                                :id 0
                                                                                                                                                                                :label_card {}
                                                                                                                                                                                :maturity_date ""
                                                                                                                                                                                :monetary_account_id 0
                                                                                                                                                                                :pan_entry_mode_user ""
                                                                                                                                                                                :payment_status ""
                                                                                                                                                                                :pos_card_holder_presence ""
                                                                                                                                                                                :pos_card_presence ""
                                                                                                                                                                                :request_reference_split_the_bill [{}]
                                                                                                                                                                                :reservation_expiry_time ""
                                                                                                                                                                                :secure_code_id 0
                                                                                                                                                                                :settlement_status ""
                                                                                                                                                                                :token_status ""
                                                                                                                                                                                :wallet_provider_id ""}
                                                                                                                                                             :Payment {}
                                                                                                                                                             :PaymentBatch {}
                                                                                                                                                             :RequestResponse {:address_billing {}
                                                                                                                                                                               :address_shipping {}
                                                                                                                                                                               :alias {}
                                                                                                                                                                               :amount_inquired {}
                                                                                                                                                                               :amount_responded {}
                                                                                                                                                                               :attachment [{:content_type ""
                                                                                                                                                                                             :description ""
                                                                                                                                                                                             :urls [{:type ""
                                                                                                                                                                                                     :url ""}]}]
                                                                                                                                                                               :counterparty_alias {}
                                                                                                                                                                               :created ""
                                                                                                                                                                               :credit_scheme_identifier ""
                                                                                                                                                                               :description ""
                                                                                                                                                                               :eligible_whitelist_id 0
                                                                                                                                                                               :event_id 0
                                                                                                                                                                               :geolocation {}
                                                                                                                                                                               :id 0
                                                                                                                                                                               :mandate_identifier ""
                                                                                                                                                                               :minimum_age 0
                                                                                                                                                                               :monetary_account_id 0
                                                                                                                                                                               :redirect_url ""
                                                                                                                                                                               :request_reference_split_the_bill [{}]
                                                                                                                                                                               :require_address ""
                                                                                                                                                                               :status ""
                                                                                                                                                                               :sub_type ""
                                                                                                                                                                               :time_expiry ""
                                                                                                                                                                               :time_refund_requested ""
                                                                                                                                                                               :time_refunded ""
                                                                                                                                                                               :time_responded ""
                                                                                                                                                                               :type ""
                                                                                                                                                                               :updated ""
                                                                                                                                                                               :user_refund_requested {}}
                                                                                                                                                             :ScheduleInstance {:error_message []
                                                                                                                                                                                :request_reference_split_the_bill [{}]
                                                                                                                                                                                :result_object {:Payment {}
                                                                                                                                                                                                :PaymentBatch {}}
                                                                                                                                                                                :scheduled_object {}
                                                                                                                                                                                :state ""
                                                                                                                                                                                :time_end ""
                                                                                                                                                                                :time_start ""}
                                                                                                                                                             :TransferwisePayment {:alias {}
                                                                                                                                                                                   :amount_source {}
                                                                                                                                                                                   :amount_target {}
                                                                                                                                                                                   :counterparty_alias {}
                                                                                                                                                                                   :monetary_account_id ""
                                                                                                                                                                                   :pay_in_reference ""
                                                                                                                                                                                   :quote {:amount_fee {}
                                                                                                                                                                                           :amount_source {}
                                                                                                                                                                                           :amount_target {}
                                                                                                                                                                                           :created ""
                                                                                                                                                                                           :currency_source ""
                                                                                                                                                                                           :currency_target ""
                                                                                                                                                                                           :id 0
                                                                                                                                                                                           :quote_id ""
                                                                                                                                                                                           :rate ""
                                                                                                                                                                                           :time_delivery_estimate ""
                                                                                                                                                                                           :time_expiry ""
                                                                                                                                                                                           :updated ""}
                                                                                                                                                                                   :rate ""
                                                                                                                                                                                   :recipient_id ""
                                                                                                                                                                                   :reference ""
                                                                                                                                                                                   :status ""
                                                                                                                                                                                   :status_transferwise ""
                                                                                                                                                                                   :status_transferwise_issue ""
                                                                                                                                                                                   :sub_status ""
                                                                                                                                                                                   :time_delivery_estimate ""}
                                                                                                                                                             :WhitelistResult {:error_message []
                                                                                                                                                                               :id 0
                                                                                                                                                                               :monetary_account_paying_id 0
                                                                                                                                                                               :object {:draftPayment {}
                                                                                                                                                                                        :id 0
                                                                                                                                                                                        :requestResponse {}}
                                                                                                                                                                               :request_reference_split_the_bill [{}]
                                                                                                                                                                               :status ""
                                                                                                                                                                               :sub_status ""
                                                                                                                                                                               :whitelist {}}}
                                                                                                                                  :request_inquiries [{:address_billing {}
                                                                                                                                                       :address_shipping {}
                                                                                                                                                       :allow_amount_higher false
                                                                                                                                                       :allow_amount_lower false
                                                                                                                                                       :allow_bunqme false
                                                                                                                                                       :amount_inquired {}
                                                                                                                                                       :amount_responded {}
                                                                                                                                                       :attachment [{:id 0}]
                                                                                                                                                       :batch_id 0
                                                                                                                                                       :bunqme_share_url ""
                                                                                                                                                       :counterparty_alias {}
                                                                                                                                                       :created ""
                                                                                                                                                       :description ""
                                                                                                                                                       :event_id 0
                                                                                                                                                       :geolocation {}
                                                                                                                                                       :id 0
                                                                                                                                                       :merchant_reference ""
                                                                                                                                                       :minimum_age 0
                                                                                                                                                       :monetary_account_id 0
                                                                                                                                                       :redirect_url ""
                                                                                                                                                       :reference_split_the_bill {}
                                                                                                                                                       :require_address ""
                                                                                                                                                       :scheduled_id 0
                                                                                                                                                       :status ""
                                                                                                                                                       :time_expiry ""
                                                                                                                                                       :time_responded ""
                                                                                                                                                       :updated ""
                                                                                                                                                       :user_alias_created {}
                                                                                                                                                       :user_alias_revoked {}
                                                                                                                                                       :want_tip false}]
                                                                                                                                  :status ""
                                                                                                                                  :total_amount_inquired {}}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"event_id\": 0,\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {\n                \"currency\": \"\",\n                \"value\": \"\"\n              },\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {\n              \"altitude\": 0,\n              \"latitude\": 0,\n              \"longitude\": 0,\n              \"radius\": 0\n            },\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"request_inquiries\": [\n    {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"allow_amount_higher\": false,\n      \"allow_amount_lower\": false,\n      \"allow_bunqme\": false,\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"id\": 0\n        }\n      ],\n      \"batch_id\": 0,\n      \"bunqme_share_url\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"reference_split_the_bill\": {},\n      \"require_address\": \"\",\n      \"scheduled_id\": 0,\n      \"status\": \"\",\n      \"time_expiry\": \"\",\n      \"time_responded\": \"\",\n      \"updated\": \"\",\n      \"user_alias_created\": {},\n      \"user_alias_revoked\": {},\n      \"want_tip\": false\n    }\n  ],\n  \"status\": \"\",\n  \"total_amount_inquired\": {}\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"event_id\": 0,\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {\n                \"currency\": \"\",\n                \"value\": \"\"\n              },\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {\n              \"altitude\": 0,\n              \"latitude\": 0,\n              \"longitude\": 0,\n              \"radius\": 0\n            },\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"request_inquiries\": [\n    {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"allow_amount_higher\": false,\n      \"allow_amount_lower\": false,\n      \"allow_bunqme\": false,\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"id\": 0\n        }\n      ],\n      \"batch_id\": 0,\n      \"bunqme_share_url\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"reference_split_the_bill\": {},\n      \"require_address\": \"\",\n      \"scheduled_id\": 0,\n      \"status\": \"\",\n      \"time_expiry\": \"\",\n      \"time_responded\": \"\",\n      \"updated\": \"\",\n      \"user_alias_created\": {},\n      \"user_alias_revoked\": {},\n      \"want_tip\": false\n    }\n  ],\n  \"status\": \"\",\n  \"total_amount_inquired\": {}\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"event_id\": 0,\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {\n                \"currency\": \"\",\n                \"value\": \"\"\n              },\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {\n              \"altitude\": 0,\n              \"latitude\": 0,\n              \"longitude\": 0,\n              \"radius\": 0\n            },\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"request_inquiries\": [\n    {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"allow_amount_higher\": false,\n      \"allow_amount_lower\": false,\n      \"allow_bunqme\": false,\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"id\": 0\n        }\n      ],\n      \"batch_id\": 0,\n      \"bunqme_share_url\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"reference_split_the_bill\": {},\n      \"require_address\": \"\",\n      \"scheduled_id\": 0,\n      \"status\": \"\",\n      \"time_expiry\": \"\",\n      \"time_responded\": \"\",\n      \"updated\": \"\",\n      \"user_alias_created\": {},\n      \"user_alias_revoked\": {},\n      \"want_tip\": false\n    }\n  ],\n  \"status\": \"\",\n  \"total_amount_inquired\": {}\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch"

	payload := strings.NewReader("{\n  \"event_id\": 0,\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {\n                \"currency\": \"\",\n                \"value\": \"\"\n              },\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {\n              \"altitude\": 0,\n              \"latitude\": 0,\n              \"longitude\": 0,\n              \"radius\": 0\n            },\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"request_inquiries\": [\n    {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"allow_amount_higher\": false,\n      \"allow_amount_lower\": false,\n      \"allow_bunqme\": false,\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"id\": 0\n        }\n      ],\n      \"batch_id\": 0,\n      \"bunqme_share_url\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"reference_split_the_bill\": {},\n      \"require_address\": \"\",\n      \"scheduled_id\": 0,\n      \"status\": \"\",\n      \"time_expiry\": \"\",\n      \"time_responded\": \"\",\n      \"updated\": \"\",\n      \"user_alias_created\": {},\n      \"user_alias_revoked\": {},\n      \"want_tip\": false\n    }\n  ],\n  \"status\": \"\",\n  \"total_amount_inquired\": {}\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 10610

{
  "event_id": 0,
  "reference_split_the_bill": {
    "BillingInvoice": {
      "address": {
        "city": "",
        "country": "",
        "extra": "",
        "house_number": "",
        "is_user_address_updated": false,
        "mailbox_name": "",
        "po_box": "",
        "postal_code": "",
        "province": "",
        "street": ""
      },
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "category": "",
      "chamber_of_commerce_number": "",
      "counterparty_address": {},
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "external_url": "",
      "group": [
        {
          "instance_description": "",
          "item": [
            {
              "billing_date": "",
              "id": 0,
              "quantity": 0,
              "total_vat_exclusive": {
                "currency": "",
                "value": ""
              },
              "total_vat_inclusive": {},
              "type_description": "",
              "type_description_translated": "",
              "unit_vat_exclusive": {},
              "unit_vat_inclusive": {},
              "vat": 0
            }
          ],
          "product_vat_exclusive": {},
          "product_vat_inclusive": {},
          "type": "",
          "type_description": "",
          "type_description_translated": ""
        }
      ],
      "id": 0,
      "invoice_date": "",
      "invoice_number": "",
      "request_reference_split_the_bill": [
        {
          "id": 0,
          "type": ""
        }
      ],
      "status": "",
      "total_vat": {},
      "total_vat_exclusive": {},
      "total_vat_inclusive": {},
      "updated": "",
      "vat_number": ""
    },
    "DraftPayment": {
      "entries": [
        {
          "alias": {},
          "amount": {},
          "attachment": [
            {
              "id": 0,
              "monetary_account_id": 0
            }
          ],
          "counterparty_alias": {},
          "description": "",
          "id": 0,
          "merchant_reference": "",
          "type": ""
        }
      ],
      "number_of_required_accepts": 0,
      "previous_updated_timestamp": "",
      "schedule": {
        "object": {
          "Payment": {
            "address_billing": {},
            "address_shipping": {},
            "alias": {},
            "allow_bunqto": false,
            "amount": {},
            "attachment": [
              {}
            ],
            "balance_after_mutation": {},
            "batch_id": 0,
            "bunqto_expiry": "",
            "bunqto_share_url": "",
            "bunqto_status": "",
            "bunqto_sub_status": "",
            "bunqto_time_responded": "",
            "counterparty_alias": {},
            "created": "",
            "description": "",
            "geolocation": {
              "altitude": 0,
              "latitude": 0,
              "longitude": 0,
              "radius": 0
            },
            "id": 0,
            "merchant_reference": "",
            "monetary_account_id": 0,
            "payment_auto_allocate_instance": {
              "created": "",
              "error_message": [],
              "id": 0,
              "payment_auto_allocate_id": 0,
              "payment_batch": {
                "payments": {
                  "Payment": []
                }
              },
              "payment_id": 0,
              "status": "",
              "updated": ""
            },
            "request_reference_split_the_bill": [
              {}
            ],
            "scheduled_id": 0,
            "sub_type": "",
            "type": "",
            "updated": ""
          },
          "PaymentBatch": {}
        },
        "recurrence_size": 0,
        "recurrence_unit": "",
        "status": "",
        "time_end": "",
        "time_start": ""
      },
      "status": ""
    },
    "MasterCardAction": {
      "alias": {},
      "all_mastercard_action_refund": [
        {
          "additional_information": {
            "attachment": [
              {
                "id": 0
              }
            ],
            "category": "",
            "comment": "",
            "reason": "",
            "terms_and_conditions": ""
          },
          "alias": {},
          "amount": {},
          "attachment": [
            {}
          ],
          "category": "",
          "comment": "",
          "counterparty_alias": {},
          "created": "",
          "description": "",
          "id": 0,
          "label_card": {
            "expiry_date": "",
            "label_user": {},
            "second_line": "",
            "status": "",
            "type": "",
            "uuid": ""
          },
          "label_user_creator": {},
          "mastercard_action_id": 0,
          "reason": "",
          "reference_mastercard_action_event": [
            {
              "event_id": 0
            }
          ],
          "status": "",
          "status_description": "",
          "status_description_translated": "",
          "status_together_url": "",
          "sub_type": "",
          "terms_and_conditions": "",
          "time_refund": "",
          "type": "",
          "updated": ""
        }
      ],
      "amount_billing": {},
      "amount_converted": {},
      "amount_fee": {},
      "amount_local": {},
      "amount_original_billing": {},
      "amount_original_local": {},
      "applied_limit": "",
      "authorisation_status": "",
      "authorisation_type": "",
      "card_authorisation_id_response": "",
      "card_id": 0,
      "city": "",
      "clearing_expiry_time": "",
      "clearing_status": "",
      "counterparty_alias": {},
      "decision": "",
      "decision_description": "",
      "decision_description_translated": "",
      "decision_together_url": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "id": 0,
      "label_card": {},
      "maturity_date": "",
      "monetary_account_id": 0,
      "pan_entry_mode_user": "",
      "payment_status": "",
      "pos_card_holder_presence": "",
      "pos_card_presence": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "reservation_expiry_time": "",
      "secure_code_id": 0,
      "settlement_status": "",
      "token_status": "",
      "wallet_provider_id": ""
    },
    "Payment": {},
    "PaymentBatch": {},
    "RequestResponse": {
      "address_billing": {},
      "address_shipping": {},
      "alias": {},
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "content_type": "",
          "description": "",
          "urls": [
            {
              "type": "",
              "url": ""
            }
          ]
        }
      ],
      "counterparty_alias": {},
      "created": "",
      "credit_scheme_identifier": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "mandate_identifier": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "require_address": "",
      "status": "",
      "sub_type": "",
      "time_expiry": "",
      "time_refund_requested": "",
      "time_refunded": "",
      "time_responded": "",
      "type": "",
      "updated": "",
      "user_refund_requested": {}
    },
    "ScheduleInstance": {
      "error_message": [],
      "request_reference_split_the_bill": [
        {}
      ],
      "result_object": {
        "Payment": {},
        "PaymentBatch": {}
      },
      "scheduled_object": {},
      "state": "",
      "time_end": "",
      "time_start": ""
    },
    "TransferwisePayment": {
      "alias": {},
      "amount_source": {},
      "amount_target": {},
      "counterparty_alias": {},
      "monetary_account_id": "",
      "pay_in_reference": "",
      "quote": {
        "amount_fee": {},
        "amount_source": {},
        "amount_target": {},
        "created": "",
        "currency_source": "",
        "currency_target": "",
        "id": 0,
        "quote_id": "",
        "rate": "",
        "time_delivery_estimate": "",
        "time_expiry": "",
        "updated": ""
      },
      "rate": "",
      "recipient_id": "",
      "reference": "",
      "status": "",
      "status_transferwise": "",
      "status_transferwise_issue": "",
      "sub_status": "",
      "time_delivery_estimate": ""
    },
    "WhitelistResult": {
      "error_message": [],
      "id": 0,
      "monetary_account_paying_id": 0,
      "object": {
        "draftPayment": {},
        "id": 0,
        "requestResponse": {}
      },
      "request_reference_split_the_bill": [
        {}
      ],
      "status": "",
      "sub_status": "",
      "whitelist": {}
    }
  },
  "request_inquiries": [
    {
      "address_billing": {},
      "address_shipping": {},
      "allow_amount_higher": false,
      "allow_amount_lower": false,
      "allow_bunqme": false,
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "id": 0
        }
      ],
      "batch_id": 0,
      "bunqme_share_url": "",
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "merchant_reference": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "reference_split_the_bill": {},
      "require_address": "",
      "scheduled_id": 0,
      "status": "",
      "time_expiry": "",
      "time_responded": "",
      "updated": "",
      "user_alias_created": {},
      "user_alias_revoked": {},
      "want_tip": false
    }
  ],
  "status": "",
  "total_amount_inquired": {}
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"event_id\": 0,\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {\n                \"currency\": \"\",\n                \"value\": \"\"\n              },\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {\n              \"altitude\": 0,\n              \"latitude\": 0,\n              \"longitude\": 0,\n              \"radius\": 0\n            },\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"request_inquiries\": [\n    {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"allow_amount_higher\": false,\n      \"allow_amount_lower\": false,\n      \"allow_bunqme\": false,\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"id\": 0\n        }\n      ],\n      \"batch_id\": 0,\n      \"bunqme_share_url\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"reference_split_the_bill\": {},\n      \"require_address\": \"\",\n      \"scheduled_id\": 0,\n      \"status\": \"\",\n      \"time_expiry\": \"\",\n      \"time_responded\": \"\",\n      \"updated\": \"\",\n      \"user_alias_created\": {},\n      \"user_alias_revoked\": {},\n      \"want_tip\": false\n    }\n  ],\n  \"status\": \"\",\n  \"total_amount_inquired\": {}\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"event_id\": 0,\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {\n                \"currency\": \"\",\n                \"value\": \"\"\n              },\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {\n              \"altitude\": 0,\n              \"latitude\": 0,\n              \"longitude\": 0,\n              \"radius\": 0\n            },\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"request_inquiries\": [\n    {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"allow_amount_higher\": false,\n      \"allow_amount_lower\": false,\n      \"allow_bunqme\": false,\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"id\": 0\n        }\n      ],\n      \"batch_id\": 0,\n      \"bunqme_share_url\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"reference_split_the_bill\": {},\n      \"require_address\": \"\",\n      \"scheduled_id\": 0,\n      \"status\": \"\",\n      \"time_expiry\": \"\",\n      \"time_responded\": \"\",\n      \"updated\": \"\",\n      \"user_alias_created\": {},\n      \"user_alias_revoked\": {},\n      \"want_tip\": false\n    }\n  ],\n  \"status\": \"\",\n  \"total_amount_inquired\": {}\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"event_id\": 0,\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {\n                \"currency\": \"\",\n                \"value\": \"\"\n              },\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {\n              \"altitude\": 0,\n              \"latitude\": 0,\n              \"longitude\": 0,\n              \"radius\": 0\n            },\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"request_inquiries\": [\n    {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"allow_amount_higher\": false,\n      \"allow_amount_lower\": false,\n      \"allow_bunqme\": false,\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"id\": 0\n        }\n      ],\n      \"batch_id\": 0,\n      \"bunqme_share_url\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"reference_split_the_bill\": {},\n      \"require_address\": \"\",\n      \"scheduled_id\": 0,\n      \"status\": \"\",\n      \"time_expiry\": \"\",\n      \"time_responded\": \"\",\n      \"updated\": \"\",\n      \"user_alias_created\": {},\n      \"user_alias_revoked\": {},\n      \"want_tip\": false\n    }\n  ],\n  \"status\": \"\",\n  \"total_amount_inquired\": {}\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"event_id\": 0,\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {\n                \"currency\": \"\",\n                \"value\": \"\"\n              },\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {\n              \"altitude\": 0,\n              \"latitude\": 0,\n              \"longitude\": 0,\n              \"radius\": 0\n            },\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"request_inquiries\": [\n    {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"allow_amount_higher\": false,\n      \"allow_amount_lower\": false,\n      \"allow_bunqme\": false,\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"id\": 0\n        }\n      ],\n      \"batch_id\": 0,\n      \"bunqme_share_url\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"reference_split_the_bill\": {},\n      \"require_address\": \"\",\n      \"scheduled_id\": 0,\n      \"status\": \"\",\n      \"time_expiry\": \"\",\n      \"time_responded\": \"\",\n      \"updated\": \"\",\n      \"user_alias_created\": {},\n      \"user_alias_revoked\": {},\n      \"want_tip\": false\n    }\n  ],\n  \"status\": \"\",\n  \"total_amount_inquired\": {}\n}")
  .asString();
const data = JSON.stringify({
  event_id: 0,
  reference_split_the_bill: {
    BillingInvoice: {
      address: {
        city: '',
        country: '',
        extra: '',
        house_number: '',
        is_user_address_updated: false,
        mailbox_name: '',
        po_box: '',
        postal_code: '',
        province: '',
        street: ''
      },
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [
            {
              attachment_public_uuid: '',
              content_type: '',
              height: 0,
              width: 0
            }
          ],
          style: '',
          uuid: ''
        },
        bunq_me: {
          name: '',
          service: '',
          type: '',
          value: ''
        },
        country: '',
        display_name: '',
        iban: '',
        is_light: false,
        label_user: {
          avatar: {},
          country: '',
          display_name: '',
          public_nick_name: '',
          uuid: ''
        },
        merchant_category_code: '',
        swift_account_number: '',
        swift_bic: '',
        transferwise_account_number: '',
        transferwise_bank_code: ''
      },
      category: '',
      chamber_of_commerce_number: '',
      counterparty_address: {},
      counterparty_alias: {},
      created: '',
      description: '',
      external_url: '',
      group: [
        {
          instance_description: '',
          item: [
            {
              billing_date: '',
              id: 0,
              quantity: 0,
              total_vat_exclusive: {
                currency: '',
                value: ''
              },
              total_vat_inclusive: {},
              type_description: '',
              type_description_translated: '',
              unit_vat_exclusive: {},
              unit_vat_inclusive: {},
              vat: 0
            }
          ],
          product_vat_exclusive: {},
          product_vat_inclusive: {},
          type: '',
          type_description: '',
          type_description_translated: ''
        }
      ],
      id: 0,
      invoice_date: '',
      invoice_number: '',
      request_reference_split_the_bill: [
        {
          id: 0,
          type: ''
        }
      ],
      status: '',
      total_vat: {},
      total_vat_exclusive: {},
      total_vat_inclusive: {},
      updated: '',
      vat_number: ''
    },
    DraftPayment: {
      entries: [
        {
          alias: {},
          amount: {},
          attachment: [
            {
              id: 0,
              monetary_account_id: 0
            }
          ],
          counterparty_alias: {},
          description: '',
          id: 0,
          merchant_reference: '',
          type: ''
        }
      ],
      number_of_required_accepts: 0,
      previous_updated_timestamp: '',
      schedule: {
        object: {
          Payment: {
            address_billing: {},
            address_shipping: {},
            alias: {},
            allow_bunqto: false,
            amount: {},
            attachment: [
              {}
            ],
            balance_after_mutation: {},
            batch_id: 0,
            bunqto_expiry: '',
            bunqto_share_url: '',
            bunqto_status: '',
            bunqto_sub_status: '',
            bunqto_time_responded: '',
            counterparty_alias: {},
            created: '',
            description: '',
            geolocation: {
              altitude: 0,
              latitude: 0,
              longitude: 0,
              radius: 0
            },
            id: 0,
            merchant_reference: '',
            monetary_account_id: 0,
            payment_auto_allocate_instance: {
              created: '',
              error_message: [],
              id: 0,
              payment_auto_allocate_id: 0,
              payment_batch: {
                payments: {
                  Payment: []
                }
              },
              payment_id: 0,
              status: '',
              updated: ''
            },
            request_reference_split_the_bill: [
              {}
            ],
            scheduled_id: 0,
            sub_type: '',
            type: '',
            updated: ''
          },
          PaymentBatch: {}
        },
        recurrence_size: 0,
        recurrence_unit: '',
        status: '',
        time_end: '',
        time_start: ''
      },
      status: ''
    },
    MasterCardAction: {
      alias: {},
      all_mastercard_action_refund: [
        {
          additional_information: {
            attachment: [
              {
                id: 0
              }
            ],
            category: '',
            comment: '',
            reason: '',
            terms_and_conditions: ''
          },
          alias: {},
          amount: {},
          attachment: [
            {}
          ],
          category: '',
          comment: '',
          counterparty_alias: {},
          created: '',
          description: '',
          id: 0,
          label_card: {
            expiry_date: '',
            label_user: {},
            second_line: '',
            status: '',
            type: '',
            uuid: ''
          },
          label_user_creator: {},
          mastercard_action_id: 0,
          reason: '',
          reference_mastercard_action_event: [
            {
              event_id: 0
            }
          ],
          status: '',
          status_description: '',
          status_description_translated: '',
          status_together_url: '',
          sub_type: '',
          terms_and_conditions: '',
          time_refund: '',
          type: '',
          updated: ''
        }
      ],
      amount_billing: {},
      amount_converted: {},
      amount_fee: {},
      amount_local: {},
      amount_original_billing: {},
      amount_original_local: {},
      applied_limit: '',
      authorisation_status: '',
      authorisation_type: '',
      card_authorisation_id_response: '',
      card_id: 0,
      city: '',
      clearing_expiry_time: '',
      clearing_status: '',
      counterparty_alias: {},
      decision: '',
      decision_description: '',
      decision_description_translated: '',
      decision_together_url: '',
      description: '',
      eligible_whitelist_id: 0,
      id: 0,
      label_card: {},
      maturity_date: '',
      monetary_account_id: 0,
      pan_entry_mode_user: '',
      payment_status: '',
      pos_card_holder_presence: '',
      pos_card_presence: '',
      request_reference_split_the_bill: [
        {}
      ],
      reservation_expiry_time: '',
      secure_code_id: 0,
      settlement_status: '',
      token_status: '',
      wallet_provider_id: ''
    },
    Payment: {},
    PaymentBatch: {},
    RequestResponse: {
      address_billing: {},
      address_shipping: {},
      alias: {},
      amount_inquired: {},
      amount_responded: {},
      attachment: [
        {
          content_type: '',
          description: '',
          urls: [
            {
              type: '',
              url: ''
            }
          ]
        }
      ],
      counterparty_alias: {},
      created: '',
      credit_scheme_identifier: '',
      description: '',
      eligible_whitelist_id: 0,
      event_id: 0,
      geolocation: {},
      id: 0,
      mandate_identifier: '',
      minimum_age: 0,
      monetary_account_id: 0,
      redirect_url: '',
      request_reference_split_the_bill: [
        {}
      ],
      require_address: '',
      status: '',
      sub_type: '',
      time_expiry: '',
      time_refund_requested: '',
      time_refunded: '',
      time_responded: '',
      type: '',
      updated: '',
      user_refund_requested: {}
    },
    ScheduleInstance: {
      error_message: [],
      request_reference_split_the_bill: [
        {}
      ],
      result_object: {
        Payment: {},
        PaymentBatch: {}
      },
      scheduled_object: {},
      state: '',
      time_end: '',
      time_start: ''
    },
    TransferwisePayment: {
      alias: {},
      amount_source: {},
      amount_target: {},
      counterparty_alias: {},
      monetary_account_id: '',
      pay_in_reference: '',
      quote: {
        amount_fee: {},
        amount_source: {},
        amount_target: {},
        created: '',
        currency_source: '',
        currency_target: '',
        id: 0,
        quote_id: '',
        rate: '',
        time_delivery_estimate: '',
        time_expiry: '',
        updated: ''
      },
      rate: '',
      recipient_id: '',
      reference: '',
      status: '',
      status_transferwise: '',
      status_transferwise_issue: '',
      sub_status: '',
      time_delivery_estimate: ''
    },
    WhitelistResult: {
      error_message: [],
      id: 0,
      monetary_account_paying_id: 0,
      object: {
        draftPayment: {},
        id: 0,
        requestResponse: {}
      },
      request_reference_split_the_bill: [
        {}
      ],
      status: '',
      sub_status: '',
      whitelist: {}
    }
  },
  request_inquiries: [
    {
      address_billing: {},
      address_shipping: {},
      allow_amount_higher: false,
      allow_amount_lower: false,
      allow_bunqme: false,
      amount_inquired: {},
      amount_responded: {},
      attachment: [
        {
          id: 0
        }
      ],
      batch_id: 0,
      bunqme_share_url: '',
      counterparty_alias: {},
      created: '',
      description: '',
      event_id: 0,
      geolocation: {},
      id: 0,
      merchant_reference: '',
      minimum_age: 0,
      monetary_account_id: 0,
      redirect_url: '',
      reference_split_the_bill: {},
      require_address: '',
      scheduled_id: 0,
      status: '',
      time_expiry: '',
      time_responded: '',
      updated: '',
      user_alias_created: {},
      user_alias_revoked: {},
      want_tip: false
    }
  ],
  status: '',
  total_amount_inquired: {}
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    event_id: 0,
    reference_split_the_bill: {
      BillingInvoice: {
        address: {
          city: '',
          country: '',
          extra: '',
          house_number: '',
          is_user_address_updated: false,
          mailbox_name: '',
          po_box: '',
          postal_code: '',
          province: '',
          street: ''
        },
        alias: {
          avatar: {
            anchor_uuid: '',
            image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
            style: '',
            uuid: ''
          },
          bunq_me: {name: '', service: '', type: '', value: ''},
          country: '',
          display_name: '',
          iban: '',
          is_light: false,
          label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
          merchant_category_code: '',
          swift_account_number: '',
          swift_bic: '',
          transferwise_account_number: '',
          transferwise_bank_code: ''
        },
        category: '',
        chamber_of_commerce_number: '',
        counterparty_address: {},
        counterparty_alias: {},
        created: '',
        description: '',
        external_url: '',
        group: [
          {
            instance_description: '',
            item: [
              {
                billing_date: '',
                id: 0,
                quantity: 0,
                total_vat_exclusive: {currency: '', value: ''},
                total_vat_inclusive: {},
                type_description: '',
                type_description_translated: '',
                unit_vat_exclusive: {},
                unit_vat_inclusive: {},
                vat: 0
              }
            ],
            product_vat_exclusive: {},
            product_vat_inclusive: {},
            type: '',
            type_description: '',
            type_description_translated: ''
          }
        ],
        id: 0,
        invoice_date: '',
        invoice_number: '',
        request_reference_split_the_bill: [{id: 0, type: ''}],
        status: '',
        total_vat: {},
        total_vat_exclusive: {},
        total_vat_inclusive: {},
        updated: '',
        vat_number: ''
      },
      DraftPayment: {
        entries: [
          {
            alias: {},
            amount: {},
            attachment: [{id: 0, monetary_account_id: 0}],
            counterparty_alias: {},
            description: '',
            id: 0,
            merchant_reference: '',
            type: ''
          }
        ],
        number_of_required_accepts: 0,
        previous_updated_timestamp: '',
        schedule: {
          object: {
            Payment: {
              address_billing: {},
              address_shipping: {},
              alias: {},
              allow_bunqto: false,
              amount: {},
              attachment: [{}],
              balance_after_mutation: {},
              batch_id: 0,
              bunqto_expiry: '',
              bunqto_share_url: '',
              bunqto_status: '',
              bunqto_sub_status: '',
              bunqto_time_responded: '',
              counterparty_alias: {},
              created: '',
              description: '',
              geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
              id: 0,
              merchant_reference: '',
              monetary_account_id: 0,
              payment_auto_allocate_instance: {
                created: '',
                error_message: [],
                id: 0,
                payment_auto_allocate_id: 0,
                payment_batch: {payments: {Payment: []}},
                payment_id: 0,
                status: '',
                updated: ''
              },
              request_reference_split_the_bill: [{}],
              scheduled_id: 0,
              sub_type: '',
              type: '',
              updated: ''
            },
            PaymentBatch: {}
          },
          recurrence_size: 0,
          recurrence_unit: '',
          status: '',
          time_end: '',
          time_start: ''
        },
        status: ''
      },
      MasterCardAction: {
        alias: {},
        all_mastercard_action_refund: [
          {
            additional_information: {
              attachment: [{id: 0}],
              category: '',
              comment: '',
              reason: '',
              terms_and_conditions: ''
            },
            alias: {},
            amount: {},
            attachment: [{}],
            category: '',
            comment: '',
            counterparty_alias: {},
            created: '',
            description: '',
            id: 0,
            label_card: {
              expiry_date: '',
              label_user: {},
              second_line: '',
              status: '',
              type: '',
              uuid: ''
            },
            label_user_creator: {},
            mastercard_action_id: 0,
            reason: '',
            reference_mastercard_action_event: [{event_id: 0}],
            status: '',
            status_description: '',
            status_description_translated: '',
            status_together_url: '',
            sub_type: '',
            terms_and_conditions: '',
            time_refund: '',
            type: '',
            updated: ''
          }
        ],
        amount_billing: {},
        amount_converted: {},
        amount_fee: {},
        amount_local: {},
        amount_original_billing: {},
        amount_original_local: {},
        applied_limit: '',
        authorisation_status: '',
        authorisation_type: '',
        card_authorisation_id_response: '',
        card_id: 0,
        city: '',
        clearing_expiry_time: '',
        clearing_status: '',
        counterparty_alias: {},
        decision: '',
        decision_description: '',
        decision_description_translated: '',
        decision_together_url: '',
        description: '',
        eligible_whitelist_id: 0,
        id: 0,
        label_card: {},
        maturity_date: '',
        monetary_account_id: 0,
        pan_entry_mode_user: '',
        payment_status: '',
        pos_card_holder_presence: '',
        pos_card_presence: '',
        request_reference_split_the_bill: [{}],
        reservation_expiry_time: '',
        secure_code_id: 0,
        settlement_status: '',
        token_status: '',
        wallet_provider_id: ''
      },
      Payment: {},
      PaymentBatch: {},
      RequestResponse: {
        address_billing: {},
        address_shipping: {},
        alias: {},
        amount_inquired: {},
        amount_responded: {},
        attachment: [{content_type: '', description: '', urls: [{type: '', url: ''}]}],
        counterparty_alias: {},
        created: '',
        credit_scheme_identifier: '',
        description: '',
        eligible_whitelist_id: 0,
        event_id: 0,
        geolocation: {},
        id: 0,
        mandate_identifier: '',
        minimum_age: 0,
        monetary_account_id: 0,
        redirect_url: '',
        request_reference_split_the_bill: [{}],
        require_address: '',
        status: '',
        sub_type: '',
        time_expiry: '',
        time_refund_requested: '',
        time_refunded: '',
        time_responded: '',
        type: '',
        updated: '',
        user_refund_requested: {}
      },
      ScheduleInstance: {
        error_message: [],
        request_reference_split_the_bill: [{}],
        result_object: {Payment: {}, PaymentBatch: {}},
        scheduled_object: {},
        state: '',
        time_end: '',
        time_start: ''
      },
      TransferwisePayment: {
        alias: {},
        amount_source: {},
        amount_target: {},
        counterparty_alias: {},
        monetary_account_id: '',
        pay_in_reference: '',
        quote: {
          amount_fee: {},
          amount_source: {},
          amount_target: {},
          created: '',
          currency_source: '',
          currency_target: '',
          id: 0,
          quote_id: '',
          rate: '',
          time_delivery_estimate: '',
          time_expiry: '',
          updated: ''
        },
        rate: '',
        recipient_id: '',
        reference: '',
        status: '',
        status_transferwise: '',
        status_transferwise_issue: '',
        sub_status: '',
        time_delivery_estimate: ''
      },
      WhitelistResult: {
        error_message: [],
        id: 0,
        monetary_account_paying_id: 0,
        object: {draftPayment: {}, id: 0, requestResponse: {}},
        request_reference_split_the_bill: [{}],
        status: '',
        sub_status: '',
        whitelist: {}
      }
    },
    request_inquiries: [
      {
        address_billing: {},
        address_shipping: {},
        allow_amount_higher: false,
        allow_amount_lower: false,
        allow_bunqme: false,
        amount_inquired: {},
        amount_responded: {},
        attachment: [{id: 0}],
        batch_id: 0,
        bunqme_share_url: '',
        counterparty_alias: {},
        created: '',
        description: '',
        event_id: 0,
        geolocation: {},
        id: 0,
        merchant_reference: '',
        minimum_age: 0,
        monetary_account_id: 0,
        redirect_url: '',
        reference_split_the_bill: {},
        require_address: '',
        scheduled_id: 0,
        status: '',
        time_expiry: '',
        time_responded: '',
        updated: '',
        user_alias_created: {},
        user_alias_revoked: {},
        want_tip: false
      }
    ],
    status: '',
    total_amount_inquired: {}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"event_id":0,"reference_split_the_bill":{"BillingInvoice":{"address":{"city":"","country":"","extra":"","house_number":"","is_user_address_updated":false,"mailbox_name":"","po_box":"","postal_code":"","province":"","street":""},"alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"category":"","chamber_of_commerce_number":"","counterparty_address":{},"counterparty_alias":{},"created":"","description":"","external_url":"","group":[{"instance_description":"","item":[{"billing_date":"","id":0,"quantity":0,"total_vat_exclusive":{"currency":"","value":""},"total_vat_inclusive":{},"type_description":"","type_description_translated":"","unit_vat_exclusive":{},"unit_vat_inclusive":{},"vat":0}],"product_vat_exclusive":{},"product_vat_inclusive":{},"type":"","type_description":"","type_description_translated":""}],"id":0,"invoice_date":"","invoice_number":"","request_reference_split_the_bill":[{"id":0,"type":""}],"status":"","total_vat":{},"total_vat_exclusive":{},"total_vat_inclusive":{},"updated":"","vat_number":""},"DraftPayment":{"entries":[{"alias":{},"amount":{},"attachment":[{"id":0,"monetary_account_id":0}],"counterparty_alias":{},"description":"","id":0,"merchant_reference":"","type":""}],"number_of_required_accepts":0,"previous_updated_timestamp":"","schedule":{"object":{"Payment":{"address_billing":{},"address_shipping":{},"alias":{},"allow_bunqto":false,"amount":{},"attachment":[{}],"balance_after_mutation":{},"batch_id":0,"bunqto_expiry":"","bunqto_share_url":"","bunqto_status":"","bunqto_sub_status":"","bunqto_time_responded":"","counterparty_alias":{},"created":"","description":"","geolocation":{"altitude":0,"latitude":0,"longitude":0,"radius":0},"id":0,"merchant_reference":"","monetary_account_id":0,"payment_auto_allocate_instance":{"created":"","error_message":[],"id":0,"payment_auto_allocate_id":0,"payment_batch":{"payments":{"Payment":[]}},"payment_id":0,"status":"","updated":""},"request_reference_split_the_bill":[{}],"scheduled_id":0,"sub_type":"","type":"","updated":""},"PaymentBatch":{}},"recurrence_size":0,"recurrence_unit":"","status":"","time_end":"","time_start":""},"status":""},"MasterCardAction":{"alias":{},"all_mastercard_action_refund":[{"additional_information":{"attachment":[{"id":0}],"category":"","comment":"","reason":"","terms_and_conditions":""},"alias":{},"amount":{},"attachment":[{}],"category":"","comment":"","counterparty_alias":{},"created":"","description":"","id":0,"label_card":{"expiry_date":"","label_user":{},"second_line":"","status":"","type":"","uuid":""},"label_user_creator":{},"mastercard_action_id":0,"reason":"","reference_mastercard_action_event":[{"event_id":0}],"status":"","status_description":"","status_description_translated":"","status_together_url":"","sub_type":"","terms_and_conditions":"","time_refund":"","type":"","updated":""}],"amount_billing":{},"amount_converted":{},"amount_fee":{},"amount_local":{},"amount_original_billing":{},"amount_original_local":{},"applied_limit":"","authorisation_status":"","authorisation_type":"","card_authorisation_id_response":"","card_id":0,"city":"","clearing_expiry_time":"","clearing_status":"","counterparty_alias":{},"decision":"","decision_description":"","decision_description_translated":"","decision_together_url":"","description":"","eligible_whitelist_id":0,"id":0,"label_card":{},"maturity_date":"","monetary_account_id":0,"pan_entry_mode_user":"","payment_status":"","pos_card_holder_presence":"","pos_card_presence":"","request_reference_split_the_bill":[{}],"reservation_expiry_time":"","secure_code_id":0,"settlement_status":"","token_status":"","wallet_provider_id":""},"Payment":{},"PaymentBatch":{},"RequestResponse":{"address_billing":{},"address_shipping":{},"alias":{},"amount_inquired":{},"amount_responded":{},"attachment":[{"content_type":"","description":"","urls":[{"type":"","url":""}]}],"counterparty_alias":{},"created":"","credit_scheme_identifier":"","description":"","eligible_whitelist_id":0,"event_id":0,"geolocation":{},"id":0,"mandate_identifier":"","minimum_age":0,"monetary_account_id":0,"redirect_url":"","request_reference_split_the_bill":[{}],"require_address":"","status":"","sub_type":"","time_expiry":"","time_refund_requested":"","time_refunded":"","time_responded":"","type":"","updated":"","user_refund_requested":{}},"ScheduleInstance":{"error_message":[],"request_reference_split_the_bill":[{}],"result_object":{"Payment":{},"PaymentBatch":{}},"scheduled_object":{},"state":"","time_end":"","time_start":""},"TransferwisePayment":{"alias":{},"amount_source":{},"amount_target":{},"counterparty_alias":{},"monetary_account_id":"","pay_in_reference":"","quote":{"amount_fee":{},"amount_source":{},"amount_target":{},"created":"","currency_source":"","currency_target":"","id":0,"quote_id":"","rate":"","time_delivery_estimate":"","time_expiry":"","updated":""},"rate":"","recipient_id":"","reference":"","status":"","status_transferwise":"","status_transferwise_issue":"","sub_status":"","time_delivery_estimate":""},"WhitelistResult":{"error_message":[],"id":0,"monetary_account_paying_id":0,"object":{"draftPayment":{},"id":0,"requestResponse":{}},"request_reference_split_the_bill":[{}],"status":"","sub_status":"","whitelist":{}}},"request_inquiries":[{"address_billing":{},"address_shipping":{},"allow_amount_higher":false,"allow_amount_lower":false,"allow_bunqme":false,"amount_inquired":{},"amount_responded":{},"attachment":[{"id":0}],"batch_id":0,"bunqme_share_url":"","counterparty_alias":{},"created":"","description":"","event_id":0,"geolocation":{},"id":0,"merchant_reference":"","minimum_age":0,"monetary_account_id":0,"redirect_url":"","reference_split_the_bill":{},"require_address":"","scheduled_id":0,"status":"","time_expiry":"","time_responded":"","updated":"","user_alias_created":{},"user_alias_revoked":{},"want_tip":false}],"status":"","total_amount_inquired":{}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "event_id": 0,\n  "reference_split_the_bill": {\n    "BillingInvoice": {\n      "address": {\n        "city": "",\n        "country": "",\n        "extra": "",\n        "house_number": "",\n        "is_user_address_updated": false,\n        "mailbox_name": "",\n        "po_box": "",\n        "postal_code": "",\n        "province": "",\n        "street": ""\n      },\n      "alias": {\n        "avatar": {\n          "anchor_uuid": "",\n          "image": [\n            {\n              "attachment_public_uuid": "",\n              "content_type": "",\n              "height": 0,\n              "width": 0\n            }\n          ],\n          "style": "",\n          "uuid": ""\n        },\n        "bunq_me": {\n          "name": "",\n          "service": "",\n          "type": "",\n          "value": ""\n        },\n        "country": "",\n        "display_name": "",\n        "iban": "",\n        "is_light": false,\n        "label_user": {\n          "avatar": {},\n          "country": "",\n          "display_name": "",\n          "public_nick_name": "",\n          "uuid": ""\n        },\n        "merchant_category_code": "",\n        "swift_account_number": "",\n        "swift_bic": "",\n        "transferwise_account_number": "",\n        "transferwise_bank_code": ""\n      },\n      "category": "",\n      "chamber_of_commerce_number": "",\n      "counterparty_address": {},\n      "counterparty_alias": {},\n      "created": "",\n      "description": "",\n      "external_url": "",\n      "group": [\n        {\n          "instance_description": "",\n          "item": [\n            {\n              "billing_date": "",\n              "id": 0,\n              "quantity": 0,\n              "total_vat_exclusive": {\n                "currency": "",\n                "value": ""\n              },\n              "total_vat_inclusive": {},\n              "type_description": "",\n              "type_description_translated": "",\n              "unit_vat_exclusive": {},\n              "unit_vat_inclusive": {},\n              "vat": 0\n            }\n          ],\n          "product_vat_exclusive": {},\n          "product_vat_inclusive": {},\n          "type": "",\n          "type_description": "",\n          "type_description_translated": ""\n        }\n      ],\n      "id": 0,\n      "invoice_date": "",\n      "invoice_number": "",\n      "request_reference_split_the_bill": [\n        {\n          "id": 0,\n          "type": ""\n        }\n      ],\n      "status": "",\n      "total_vat": {},\n      "total_vat_exclusive": {},\n      "total_vat_inclusive": {},\n      "updated": "",\n      "vat_number": ""\n    },\n    "DraftPayment": {\n      "entries": [\n        {\n          "alias": {},\n          "amount": {},\n          "attachment": [\n            {\n              "id": 0,\n              "monetary_account_id": 0\n            }\n          ],\n          "counterparty_alias": {},\n          "description": "",\n          "id": 0,\n          "merchant_reference": "",\n          "type": ""\n        }\n      ],\n      "number_of_required_accepts": 0,\n      "previous_updated_timestamp": "",\n      "schedule": {\n        "object": {\n          "Payment": {\n            "address_billing": {},\n            "address_shipping": {},\n            "alias": {},\n            "allow_bunqto": false,\n            "amount": {},\n            "attachment": [\n              {}\n            ],\n            "balance_after_mutation": {},\n            "batch_id": 0,\n            "bunqto_expiry": "",\n            "bunqto_share_url": "",\n            "bunqto_status": "",\n            "bunqto_sub_status": "",\n            "bunqto_time_responded": "",\n            "counterparty_alias": {},\n            "created": "",\n            "description": "",\n            "geolocation": {\n              "altitude": 0,\n              "latitude": 0,\n              "longitude": 0,\n              "radius": 0\n            },\n            "id": 0,\n            "merchant_reference": "",\n            "monetary_account_id": 0,\n            "payment_auto_allocate_instance": {\n              "created": "",\n              "error_message": [],\n              "id": 0,\n              "payment_auto_allocate_id": 0,\n              "payment_batch": {\n                "payments": {\n                  "Payment": []\n                }\n              },\n              "payment_id": 0,\n              "status": "",\n              "updated": ""\n            },\n            "request_reference_split_the_bill": [\n              {}\n            ],\n            "scheduled_id": 0,\n            "sub_type": "",\n            "type": "",\n            "updated": ""\n          },\n          "PaymentBatch": {}\n        },\n        "recurrence_size": 0,\n        "recurrence_unit": "",\n        "status": "",\n        "time_end": "",\n        "time_start": ""\n      },\n      "status": ""\n    },\n    "MasterCardAction": {\n      "alias": {},\n      "all_mastercard_action_refund": [\n        {\n          "additional_information": {\n            "attachment": [\n              {\n                "id": 0\n              }\n            ],\n            "category": "",\n            "comment": "",\n            "reason": "",\n            "terms_and_conditions": ""\n          },\n          "alias": {},\n          "amount": {},\n          "attachment": [\n            {}\n          ],\n          "category": "",\n          "comment": "",\n          "counterparty_alias": {},\n          "created": "",\n          "description": "",\n          "id": 0,\n          "label_card": {\n            "expiry_date": "",\n            "label_user": {},\n            "second_line": "",\n            "status": "",\n            "type": "",\n            "uuid": ""\n          },\n          "label_user_creator": {},\n          "mastercard_action_id": 0,\n          "reason": "",\n          "reference_mastercard_action_event": [\n            {\n              "event_id": 0\n            }\n          ],\n          "status": "",\n          "status_description": "",\n          "status_description_translated": "",\n          "status_together_url": "",\n          "sub_type": "",\n          "terms_and_conditions": "",\n          "time_refund": "",\n          "type": "",\n          "updated": ""\n        }\n      ],\n      "amount_billing": {},\n      "amount_converted": {},\n      "amount_fee": {},\n      "amount_local": {},\n      "amount_original_billing": {},\n      "amount_original_local": {},\n      "applied_limit": "",\n      "authorisation_status": "",\n      "authorisation_type": "",\n      "card_authorisation_id_response": "",\n      "card_id": 0,\n      "city": "",\n      "clearing_expiry_time": "",\n      "clearing_status": "",\n      "counterparty_alias": {},\n      "decision": "",\n      "decision_description": "",\n      "decision_description_translated": "",\n      "decision_together_url": "",\n      "description": "",\n      "eligible_whitelist_id": 0,\n      "id": 0,\n      "label_card": {},\n      "maturity_date": "",\n      "monetary_account_id": 0,\n      "pan_entry_mode_user": "",\n      "payment_status": "",\n      "pos_card_holder_presence": "",\n      "pos_card_presence": "",\n      "request_reference_split_the_bill": [\n        {}\n      ],\n      "reservation_expiry_time": "",\n      "secure_code_id": 0,\n      "settlement_status": "",\n      "token_status": "",\n      "wallet_provider_id": ""\n    },\n    "Payment": {},\n    "PaymentBatch": {},\n    "RequestResponse": {\n      "address_billing": {},\n      "address_shipping": {},\n      "alias": {},\n      "amount_inquired": {},\n      "amount_responded": {},\n      "attachment": [\n        {\n          "content_type": "",\n          "description": "",\n          "urls": [\n            {\n              "type": "",\n              "url": ""\n            }\n          ]\n        }\n      ],\n      "counterparty_alias": {},\n      "created": "",\n      "credit_scheme_identifier": "",\n      "description": "",\n      "eligible_whitelist_id": 0,\n      "event_id": 0,\n      "geolocation": {},\n      "id": 0,\n      "mandate_identifier": "",\n      "minimum_age": 0,\n      "monetary_account_id": 0,\n      "redirect_url": "",\n      "request_reference_split_the_bill": [\n        {}\n      ],\n      "require_address": "",\n      "status": "",\n      "sub_type": "",\n      "time_expiry": "",\n      "time_refund_requested": "",\n      "time_refunded": "",\n      "time_responded": "",\n      "type": "",\n      "updated": "",\n      "user_refund_requested": {}\n    },\n    "ScheduleInstance": {\n      "error_message": [],\n      "request_reference_split_the_bill": [\n        {}\n      ],\n      "result_object": {\n        "Payment": {},\n        "PaymentBatch": {}\n      },\n      "scheduled_object": {},\n      "state": "",\n      "time_end": "",\n      "time_start": ""\n    },\n    "TransferwisePayment": {\n      "alias": {},\n      "amount_source": {},\n      "amount_target": {},\n      "counterparty_alias": {},\n      "monetary_account_id": "",\n      "pay_in_reference": "",\n      "quote": {\n        "amount_fee": {},\n        "amount_source": {},\n        "amount_target": {},\n        "created": "",\n        "currency_source": "",\n        "currency_target": "",\n        "id": 0,\n        "quote_id": "",\n        "rate": "",\n        "time_delivery_estimate": "",\n        "time_expiry": "",\n        "updated": ""\n      },\n      "rate": "",\n      "recipient_id": "",\n      "reference": "",\n      "status": "",\n      "status_transferwise": "",\n      "status_transferwise_issue": "",\n      "sub_status": "",\n      "time_delivery_estimate": ""\n    },\n    "WhitelistResult": {\n      "error_message": [],\n      "id": 0,\n      "monetary_account_paying_id": 0,\n      "object": {\n        "draftPayment": {},\n        "id": 0,\n        "requestResponse": {}\n      },\n      "request_reference_split_the_bill": [\n        {}\n      ],\n      "status": "",\n      "sub_status": "",\n      "whitelist": {}\n    }\n  },\n  "request_inquiries": [\n    {\n      "address_billing": {},\n      "address_shipping": {},\n      "allow_amount_higher": false,\n      "allow_amount_lower": false,\n      "allow_bunqme": false,\n      "amount_inquired": {},\n      "amount_responded": {},\n      "attachment": [\n        {\n          "id": 0\n        }\n      ],\n      "batch_id": 0,\n      "bunqme_share_url": "",\n      "counterparty_alias": {},\n      "created": "",\n      "description": "",\n      "event_id": 0,\n      "geolocation": {},\n      "id": 0,\n      "merchant_reference": "",\n      "minimum_age": 0,\n      "monetary_account_id": 0,\n      "redirect_url": "",\n      "reference_split_the_bill": {},\n      "require_address": "",\n      "scheduled_id": 0,\n      "status": "",\n      "time_expiry": "",\n      "time_responded": "",\n      "updated": "",\n      "user_alias_created": {},\n      "user_alias_revoked": {},\n      "want_tip": false\n    }\n  ],\n  "status": "",\n  "total_amount_inquired": {}\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"event_id\": 0,\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {\n                \"currency\": \"\",\n                \"value\": \"\"\n              },\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {\n              \"altitude\": 0,\n              \"latitude\": 0,\n              \"longitude\": 0,\n              \"radius\": 0\n            },\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"request_inquiries\": [\n    {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"allow_amount_higher\": false,\n      \"allow_amount_lower\": false,\n      \"allow_bunqme\": false,\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"id\": 0\n        }\n      ],\n      \"batch_id\": 0,\n      \"bunqme_share_url\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"reference_split_the_bill\": {},\n      \"require_address\": \"\",\n      \"scheduled_id\": 0,\n      \"status\": \"\",\n      \"time_expiry\": \"\",\n      \"time_responded\": \"\",\n      \"updated\": \"\",\n      \"user_alias_created\": {},\n      \"user_alias_revoked\": {},\n      \"want_tip\": false\n    }\n  ],\n  \"status\": \"\",\n  \"total_amount_inquired\": {}\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  event_id: 0,
  reference_split_the_bill: {
    BillingInvoice: {
      address: {
        city: '',
        country: '',
        extra: '',
        house_number: '',
        is_user_address_updated: false,
        mailbox_name: '',
        po_box: '',
        postal_code: '',
        province: '',
        street: ''
      },
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
          style: '',
          uuid: ''
        },
        bunq_me: {name: '', service: '', type: '', value: ''},
        country: '',
        display_name: '',
        iban: '',
        is_light: false,
        label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
        merchant_category_code: '',
        swift_account_number: '',
        swift_bic: '',
        transferwise_account_number: '',
        transferwise_bank_code: ''
      },
      category: '',
      chamber_of_commerce_number: '',
      counterparty_address: {},
      counterparty_alias: {},
      created: '',
      description: '',
      external_url: '',
      group: [
        {
          instance_description: '',
          item: [
            {
              billing_date: '',
              id: 0,
              quantity: 0,
              total_vat_exclusive: {currency: '', value: ''},
              total_vat_inclusive: {},
              type_description: '',
              type_description_translated: '',
              unit_vat_exclusive: {},
              unit_vat_inclusive: {},
              vat: 0
            }
          ],
          product_vat_exclusive: {},
          product_vat_inclusive: {},
          type: '',
          type_description: '',
          type_description_translated: ''
        }
      ],
      id: 0,
      invoice_date: '',
      invoice_number: '',
      request_reference_split_the_bill: [{id: 0, type: ''}],
      status: '',
      total_vat: {},
      total_vat_exclusive: {},
      total_vat_inclusive: {},
      updated: '',
      vat_number: ''
    },
    DraftPayment: {
      entries: [
        {
          alias: {},
          amount: {},
          attachment: [{id: 0, monetary_account_id: 0}],
          counterparty_alias: {},
          description: '',
          id: 0,
          merchant_reference: '',
          type: ''
        }
      ],
      number_of_required_accepts: 0,
      previous_updated_timestamp: '',
      schedule: {
        object: {
          Payment: {
            address_billing: {},
            address_shipping: {},
            alias: {},
            allow_bunqto: false,
            amount: {},
            attachment: [{}],
            balance_after_mutation: {},
            batch_id: 0,
            bunqto_expiry: '',
            bunqto_share_url: '',
            bunqto_status: '',
            bunqto_sub_status: '',
            bunqto_time_responded: '',
            counterparty_alias: {},
            created: '',
            description: '',
            geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
            id: 0,
            merchant_reference: '',
            monetary_account_id: 0,
            payment_auto_allocate_instance: {
              created: '',
              error_message: [],
              id: 0,
              payment_auto_allocate_id: 0,
              payment_batch: {payments: {Payment: []}},
              payment_id: 0,
              status: '',
              updated: ''
            },
            request_reference_split_the_bill: [{}],
            scheduled_id: 0,
            sub_type: '',
            type: '',
            updated: ''
          },
          PaymentBatch: {}
        },
        recurrence_size: 0,
        recurrence_unit: '',
        status: '',
        time_end: '',
        time_start: ''
      },
      status: ''
    },
    MasterCardAction: {
      alias: {},
      all_mastercard_action_refund: [
        {
          additional_information: {
            attachment: [{id: 0}],
            category: '',
            comment: '',
            reason: '',
            terms_and_conditions: ''
          },
          alias: {},
          amount: {},
          attachment: [{}],
          category: '',
          comment: '',
          counterparty_alias: {},
          created: '',
          description: '',
          id: 0,
          label_card: {
            expiry_date: '',
            label_user: {},
            second_line: '',
            status: '',
            type: '',
            uuid: ''
          },
          label_user_creator: {},
          mastercard_action_id: 0,
          reason: '',
          reference_mastercard_action_event: [{event_id: 0}],
          status: '',
          status_description: '',
          status_description_translated: '',
          status_together_url: '',
          sub_type: '',
          terms_and_conditions: '',
          time_refund: '',
          type: '',
          updated: ''
        }
      ],
      amount_billing: {},
      amount_converted: {},
      amount_fee: {},
      amount_local: {},
      amount_original_billing: {},
      amount_original_local: {},
      applied_limit: '',
      authorisation_status: '',
      authorisation_type: '',
      card_authorisation_id_response: '',
      card_id: 0,
      city: '',
      clearing_expiry_time: '',
      clearing_status: '',
      counterparty_alias: {},
      decision: '',
      decision_description: '',
      decision_description_translated: '',
      decision_together_url: '',
      description: '',
      eligible_whitelist_id: 0,
      id: 0,
      label_card: {},
      maturity_date: '',
      monetary_account_id: 0,
      pan_entry_mode_user: '',
      payment_status: '',
      pos_card_holder_presence: '',
      pos_card_presence: '',
      request_reference_split_the_bill: [{}],
      reservation_expiry_time: '',
      secure_code_id: 0,
      settlement_status: '',
      token_status: '',
      wallet_provider_id: ''
    },
    Payment: {},
    PaymentBatch: {},
    RequestResponse: {
      address_billing: {},
      address_shipping: {},
      alias: {},
      amount_inquired: {},
      amount_responded: {},
      attachment: [{content_type: '', description: '', urls: [{type: '', url: ''}]}],
      counterparty_alias: {},
      created: '',
      credit_scheme_identifier: '',
      description: '',
      eligible_whitelist_id: 0,
      event_id: 0,
      geolocation: {},
      id: 0,
      mandate_identifier: '',
      minimum_age: 0,
      monetary_account_id: 0,
      redirect_url: '',
      request_reference_split_the_bill: [{}],
      require_address: '',
      status: '',
      sub_type: '',
      time_expiry: '',
      time_refund_requested: '',
      time_refunded: '',
      time_responded: '',
      type: '',
      updated: '',
      user_refund_requested: {}
    },
    ScheduleInstance: {
      error_message: [],
      request_reference_split_the_bill: [{}],
      result_object: {Payment: {}, PaymentBatch: {}},
      scheduled_object: {},
      state: '',
      time_end: '',
      time_start: ''
    },
    TransferwisePayment: {
      alias: {},
      amount_source: {},
      amount_target: {},
      counterparty_alias: {},
      monetary_account_id: '',
      pay_in_reference: '',
      quote: {
        amount_fee: {},
        amount_source: {},
        amount_target: {},
        created: '',
        currency_source: '',
        currency_target: '',
        id: 0,
        quote_id: '',
        rate: '',
        time_delivery_estimate: '',
        time_expiry: '',
        updated: ''
      },
      rate: '',
      recipient_id: '',
      reference: '',
      status: '',
      status_transferwise: '',
      status_transferwise_issue: '',
      sub_status: '',
      time_delivery_estimate: ''
    },
    WhitelistResult: {
      error_message: [],
      id: 0,
      monetary_account_paying_id: 0,
      object: {draftPayment: {}, id: 0, requestResponse: {}},
      request_reference_split_the_bill: [{}],
      status: '',
      sub_status: '',
      whitelist: {}
    }
  },
  request_inquiries: [
    {
      address_billing: {},
      address_shipping: {},
      allow_amount_higher: false,
      allow_amount_lower: false,
      allow_bunqme: false,
      amount_inquired: {},
      amount_responded: {},
      attachment: [{id: 0}],
      batch_id: 0,
      bunqme_share_url: '',
      counterparty_alias: {},
      created: '',
      description: '',
      event_id: 0,
      geolocation: {},
      id: 0,
      merchant_reference: '',
      minimum_age: 0,
      monetary_account_id: 0,
      redirect_url: '',
      reference_split_the_bill: {},
      require_address: '',
      scheduled_id: 0,
      status: '',
      time_expiry: '',
      time_responded: '',
      updated: '',
      user_alias_created: {},
      user_alias_revoked: {},
      want_tip: false
    }
  ],
  status: '',
  total_amount_inquired: {}
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    event_id: 0,
    reference_split_the_bill: {
      BillingInvoice: {
        address: {
          city: '',
          country: '',
          extra: '',
          house_number: '',
          is_user_address_updated: false,
          mailbox_name: '',
          po_box: '',
          postal_code: '',
          province: '',
          street: ''
        },
        alias: {
          avatar: {
            anchor_uuid: '',
            image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
            style: '',
            uuid: ''
          },
          bunq_me: {name: '', service: '', type: '', value: ''},
          country: '',
          display_name: '',
          iban: '',
          is_light: false,
          label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
          merchant_category_code: '',
          swift_account_number: '',
          swift_bic: '',
          transferwise_account_number: '',
          transferwise_bank_code: ''
        },
        category: '',
        chamber_of_commerce_number: '',
        counterparty_address: {},
        counterparty_alias: {},
        created: '',
        description: '',
        external_url: '',
        group: [
          {
            instance_description: '',
            item: [
              {
                billing_date: '',
                id: 0,
                quantity: 0,
                total_vat_exclusive: {currency: '', value: ''},
                total_vat_inclusive: {},
                type_description: '',
                type_description_translated: '',
                unit_vat_exclusive: {},
                unit_vat_inclusive: {},
                vat: 0
              }
            ],
            product_vat_exclusive: {},
            product_vat_inclusive: {},
            type: '',
            type_description: '',
            type_description_translated: ''
          }
        ],
        id: 0,
        invoice_date: '',
        invoice_number: '',
        request_reference_split_the_bill: [{id: 0, type: ''}],
        status: '',
        total_vat: {},
        total_vat_exclusive: {},
        total_vat_inclusive: {},
        updated: '',
        vat_number: ''
      },
      DraftPayment: {
        entries: [
          {
            alias: {},
            amount: {},
            attachment: [{id: 0, monetary_account_id: 0}],
            counterparty_alias: {},
            description: '',
            id: 0,
            merchant_reference: '',
            type: ''
          }
        ],
        number_of_required_accepts: 0,
        previous_updated_timestamp: '',
        schedule: {
          object: {
            Payment: {
              address_billing: {},
              address_shipping: {},
              alias: {},
              allow_bunqto: false,
              amount: {},
              attachment: [{}],
              balance_after_mutation: {},
              batch_id: 0,
              bunqto_expiry: '',
              bunqto_share_url: '',
              bunqto_status: '',
              bunqto_sub_status: '',
              bunqto_time_responded: '',
              counterparty_alias: {},
              created: '',
              description: '',
              geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
              id: 0,
              merchant_reference: '',
              monetary_account_id: 0,
              payment_auto_allocate_instance: {
                created: '',
                error_message: [],
                id: 0,
                payment_auto_allocate_id: 0,
                payment_batch: {payments: {Payment: []}},
                payment_id: 0,
                status: '',
                updated: ''
              },
              request_reference_split_the_bill: [{}],
              scheduled_id: 0,
              sub_type: '',
              type: '',
              updated: ''
            },
            PaymentBatch: {}
          },
          recurrence_size: 0,
          recurrence_unit: '',
          status: '',
          time_end: '',
          time_start: ''
        },
        status: ''
      },
      MasterCardAction: {
        alias: {},
        all_mastercard_action_refund: [
          {
            additional_information: {
              attachment: [{id: 0}],
              category: '',
              comment: '',
              reason: '',
              terms_and_conditions: ''
            },
            alias: {},
            amount: {},
            attachment: [{}],
            category: '',
            comment: '',
            counterparty_alias: {},
            created: '',
            description: '',
            id: 0,
            label_card: {
              expiry_date: '',
              label_user: {},
              second_line: '',
              status: '',
              type: '',
              uuid: ''
            },
            label_user_creator: {},
            mastercard_action_id: 0,
            reason: '',
            reference_mastercard_action_event: [{event_id: 0}],
            status: '',
            status_description: '',
            status_description_translated: '',
            status_together_url: '',
            sub_type: '',
            terms_and_conditions: '',
            time_refund: '',
            type: '',
            updated: ''
          }
        ],
        amount_billing: {},
        amount_converted: {},
        amount_fee: {},
        amount_local: {},
        amount_original_billing: {},
        amount_original_local: {},
        applied_limit: '',
        authorisation_status: '',
        authorisation_type: '',
        card_authorisation_id_response: '',
        card_id: 0,
        city: '',
        clearing_expiry_time: '',
        clearing_status: '',
        counterparty_alias: {},
        decision: '',
        decision_description: '',
        decision_description_translated: '',
        decision_together_url: '',
        description: '',
        eligible_whitelist_id: 0,
        id: 0,
        label_card: {},
        maturity_date: '',
        monetary_account_id: 0,
        pan_entry_mode_user: '',
        payment_status: '',
        pos_card_holder_presence: '',
        pos_card_presence: '',
        request_reference_split_the_bill: [{}],
        reservation_expiry_time: '',
        secure_code_id: 0,
        settlement_status: '',
        token_status: '',
        wallet_provider_id: ''
      },
      Payment: {},
      PaymentBatch: {},
      RequestResponse: {
        address_billing: {},
        address_shipping: {},
        alias: {},
        amount_inquired: {},
        amount_responded: {},
        attachment: [{content_type: '', description: '', urls: [{type: '', url: ''}]}],
        counterparty_alias: {},
        created: '',
        credit_scheme_identifier: '',
        description: '',
        eligible_whitelist_id: 0,
        event_id: 0,
        geolocation: {},
        id: 0,
        mandate_identifier: '',
        minimum_age: 0,
        monetary_account_id: 0,
        redirect_url: '',
        request_reference_split_the_bill: [{}],
        require_address: '',
        status: '',
        sub_type: '',
        time_expiry: '',
        time_refund_requested: '',
        time_refunded: '',
        time_responded: '',
        type: '',
        updated: '',
        user_refund_requested: {}
      },
      ScheduleInstance: {
        error_message: [],
        request_reference_split_the_bill: [{}],
        result_object: {Payment: {}, PaymentBatch: {}},
        scheduled_object: {},
        state: '',
        time_end: '',
        time_start: ''
      },
      TransferwisePayment: {
        alias: {},
        amount_source: {},
        amount_target: {},
        counterparty_alias: {},
        monetary_account_id: '',
        pay_in_reference: '',
        quote: {
          amount_fee: {},
          amount_source: {},
          amount_target: {},
          created: '',
          currency_source: '',
          currency_target: '',
          id: 0,
          quote_id: '',
          rate: '',
          time_delivery_estimate: '',
          time_expiry: '',
          updated: ''
        },
        rate: '',
        recipient_id: '',
        reference: '',
        status: '',
        status_transferwise: '',
        status_transferwise_issue: '',
        sub_status: '',
        time_delivery_estimate: ''
      },
      WhitelistResult: {
        error_message: [],
        id: 0,
        monetary_account_paying_id: 0,
        object: {draftPayment: {}, id: 0, requestResponse: {}},
        request_reference_split_the_bill: [{}],
        status: '',
        sub_status: '',
        whitelist: {}
      }
    },
    request_inquiries: [
      {
        address_billing: {},
        address_shipping: {},
        allow_amount_higher: false,
        allow_amount_lower: false,
        allow_bunqme: false,
        amount_inquired: {},
        amount_responded: {},
        attachment: [{id: 0}],
        batch_id: 0,
        bunqme_share_url: '',
        counterparty_alias: {},
        created: '',
        description: '',
        event_id: 0,
        geolocation: {},
        id: 0,
        merchant_reference: '',
        minimum_age: 0,
        monetary_account_id: 0,
        redirect_url: '',
        reference_split_the_bill: {},
        require_address: '',
        scheduled_id: 0,
        status: '',
        time_expiry: '',
        time_responded: '',
        updated: '',
        user_alias_created: {},
        user_alias_revoked: {},
        want_tip: false
      }
    ],
    status: '',
    total_amount_inquired: {}
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  event_id: 0,
  reference_split_the_bill: {
    BillingInvoice: {
      address: {
        city: '',
        country: '',
        extra: '',
        house_number: '',
        is_user_address_updated: false,
        mailbox_name: '',
        po_box: '',
        postal_code: '',
        province: '',
        street: ''
      },
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [
            {
              attachment_public_uuid: '',
              content_type: '',
              height: 0,
              width: 0
            }
          ],
          style: '',
          uuid: ''
        },
        bunq_me: {
          name: '',
          service: '',
          type: '',
          value: ''
        },
        country: '',
        display_name: '',
        iban: '',
        is_light: false,
        label_user: {
          avatar: {},
          country: '',
          display_name: '',
          public_nick_name: '',
          uuid: ''
        },
        merchant_category_code: '',
        swift_account_number: '',
        swift_bic: '',
        transferwise_account_number: '',
        transferwise_bank_code: ''
      },
      category: '',
      chamber_of_commerce_number: '',
      counterparty_address: {},
      counterparty_alias: {},
      created: '',
      description: '',
      external_url: '',
      group: [
        {
          instance_description: '',
          item: [
            {
              billing_date: '',
              id: 0,
              quantity: 0,
              total_vat_exclusive: {
                currency: '',
                value: ''
              },
              total_vat_inclusive: {},
              type_description: '',
              type_description_translated: '',
              unit_vat_exclusive: {},
              unit_vat_inclusive: {},
              vat: 0
            }
          ],
          product_vat_exclusive: {},
          product_vat_inclusive: {},
          type: '',
          type_description: '',
          type_description_translated: ''
        }
      ],
      id: 0,
      invoice_date: '',
      invoice_number: '',
      request_reference_split_the_bill: [
        {
          id: 0,
          type: ''
        }
      ],
      status: '',
      total_vat: {},
      total_vat_exclusive: {},
      total_vat_inclusive: {},
      updated: '',
      vat_number: ''
    },
    DraftPayment: {
      entries: [
        {
          alias: {},
          amount: {},
          attachment: [
            {
              id: 0,
              monetary_account_id: 0
            }
          ],
          counterparty_alias: {},
          description: '',
          id: 0,
          merchant_reference: '',
          type: ''
        }
      ],
      number_of_required_accepts: 0,
      previous_updated_timestamp: '',
      schedule: {
        object: {
          Payment: {
            address_billing: {},
            address_shipping: {},
            alias: {},
            allow_bunqto: false,
            amount: {},
            attachment: [
              {}
            ],
            balance_after_mutation: {},
            batch_id: 0,
            bunqto_expiry: '',
            bunqto_share_url: '',
            bunqto_status: '',
            bunqto_sub_status: '',
            bunqto_time_responded: '',
            counterparty_alias: {},
            created: '',
            description: '',
            geolocation: {
              altitude: 0,
              latitude: 0,
              longitude: 0,
              radius: 0
            },
            id: 0,
            merchant_reference: '',
            monetary_account_id: 0,
            payment_auto_allocate_instance: {
              created: '',
              error_message: [],
              id: 0,
              payment_auto_allocate_id: 0,
              payment_batch: {
                payments: {
                  Payment: []
                }
              },
              payment_id: 0,
              status: '',
              updated: ''
            },
            request_reference_split_the_bill: [
              {}
            ],
            scheduled_id: 0,
            sub_type: '',
            type: '',
            updated: ''
          },
          PaymentBatch: {}
        },
        recurrence_size: 0,
        recurrence_unit: '',
        status: '',
        time_end: '',
        time_start: ''
      },
      status: ''
    },
    MasterCardAction: {
      alias: {},
      all_mastercard_action_refund: [
        {
          additional_information: {
            attachment: [
              {
                id: 0
              }
            ],
            category: '',
            comment: '',
            reason: '',
            terms_and_conditions: ''
          },
          alias: {},
          amount: {},
          attachment: [
            {}
          ],
          category: '',
          comment: '',
          counterparty_alias: {},
          created: '',
          description: '',
          id: 0,
          label_card: {
            expiry_date: '',
            label_user: {},
            second_line: '',
            status: '',
            type: '',
            uuid: ''
          },
          label_user_creator: {},
          mastercard_action_id: 0,
          reason: '',
          reference_mastercard_action_event: [
            {
              event_id: 0
            }
          ],
          status: '',
          status_description: '',
          status_description_translated: '',
          status_together_url: '',
          sub_type: '',
          terms_and_conditions: '',
          time_refund: '',
          type: '',
          updated: ''
        }
      ],
      amount_billing: {},
      amount_converted: {},
      amount_fee: {},
      amount_local: {},
      amount_original_billing: {},
      amount_original_local: {},
      applied_limit: '',
      authorisation_status: '',
      authorisation_type: '',
      card_authorisation_id_response: '',
      card_id: 0,
      city: '',
      clearing_expiry_time: '',
      clearing_status: '',
      counterparty_alias: {},
      decision: '',
      decision_description: '',
      decision_description_translated: '',
      decision_together_url: '',
      description: '',
      eligible_whitelist_id: 0,
      id: 0,
      label_card: {},
      maturity_date: '',
      monetary_account_id: 0,
      pan_entry_mode_user: '',
      payment_status: '',
      pos_card_holder_presence: '',
      pos_card_presence: '',
      request_reference_split_the_bill: [
        {}
      ],
      reservation_expiry_time: '',
      secure_code_id: 0,
      settlement_status: '',
      token_status: '',
      wallet_provider_id: ''
    },
    Payment: {},
    PaymentBatch: {},
    RequestResponse: {
      address_billing: {},
      address_shipping: {},
      alias: {},
      amount_inquired: {},
      amount_responded: {},
      attachment: [
        {
          content_type: '',
          description: '',
          urls: [
            {
              type: '',
              url: ''
            }
          ]
        }
      ],
      counterparty_alias: {},
      created: '',
      credit_scheme_identifier: '',
      description: '',
      eligible_whitelist_id: 0,
      event_id: 0,
      geolocation: {},
      id: 0,
      mandate_identifier: '',
      minimum_age: 0,
      monetary_account_id: 0,
      redirect_url: '',
      request_reference_split_the_bill: [
        {}
      ],
      require_address: '',
      status: '',
      sub_type: '',
      time_expiry: '',
      time_refund_requested: '',
      time_refunded: '',
      time_responded: '',
      type: '',
      updated: '',
      user_refund_requested: {}
    },
    ScheduleInstance: {
      error_message: [],
      request_reference_split_the_bill: [
        {}
      ],
      result_object: {
        Payment: {},
        PaymentBatch: {}
      },
      scheduled_object: {},
      state: '',
      time_end: '',
      time_start: ''
    },
    TransferwisePayment: {
      alias: {},
      amount_source: {},
      amount_target: {},
      counterparty_alias: {},
      monetary_account_id: '',
      pay_in_reference: '',
      quote: {
        amount_fee: {},
        amount_source: {},
        amount_target: {},
        created: '',
        currency_source: '',
        currency_target: '',
        id: 0,
        quote_id: '',
        rate: '',
        time_delivery_estimate: '',
        time_expiry: '',
        updated: ''
      },
      rate: '',
      recipient_id: '',
      reference: '',
      status: '',
      status_transferwise: '',
      status_transferwise_issue: '',
      sub_status: '',
      time_delivery_estimate: ''
    },
    WhitelistResult: {
      error_message: [],
      id: 0,
      monetary_account_paying_id: 0,
      object: {
        draftPayment: {},
        id: 0,
        requestResponse: {}
      },
      request_reference_split_the_bill: [
        {}
      ],
      status: '',
      sub_status: '',
      whitelist: {}
    }
  },
  request_inquiries: [
    {
      address_billing: {},
      address_shipping: {},
      allow_amount_higher: false,
      allow_amount_lower: false,
      allow_bunqme: false,
      amount_inquired: {},
      amount_responded: {},
      attachment: [
        {
          id: 0
        }
      ],
      batch_id: 0,
      bunqme_share_url: '',
      counterparty_alias: {},
      created: '',
      description: '',
      event_id: 0,
      geolocation: {},
      id: 0,
      merchant_reference: '',
      minimum_age: 0,
      monetary_account_id: 0,
      redirect_url: '',
      reference_split_the_bill: {},
      require_address: '',
      scheduled_id: 0,
      status: '',
      time_expiry: '',
      time_responded: '',
      updated: '',
      user_alias_created: {},
      user_alias_revoked: {},
      want_tip: false
    }
  ],
  status: '',
  total_amount_inquired: {}
});

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}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    event_id: 0,
    reference_split_the_bill: {
      BillingInvoice: {
        address: {
          city: '',
          country: '',
          extra: '',
          house_number: '',
          is_user_address_updated: false,
          mailbox_name: '',
          po_box: '',
          postal_code: '',
          province: '',
          street: ''
        },
        alias: {
          avatar: {
            anchor_uuid: '',
            image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
            style: '',
            uuid: ''
          },
          bunq_me: {name: '', service: '', type: '', value: ''},
          country: '',
          display_name: '',
          iban: '',
          is_light: false,
          label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
          merchant_category_code: '',
          swift_account_number: '',
          swift_bic: '',
          transferwise_account_number: '',
          transferwise_bank_code: ''
        },
        category: '',
        chamber_of_commerce_number: '',
        counterparty_address: {},
        counterparty_alias: {},
        created: '',
        description: '',
        external_url: '',
        group: [
          {
            instance_description: '',
            item: [
              {
                billing_date: '',
                id: 0,
                quantity: 0,
                total_vat_exclusive: {currency: '', value: ''},
                total_vat_inclusive: {},
                type_description: '',
                type_description_translated: '',
                unit_vat_exclusive: {},
                unit_vat_inclusive: {},
                vat: 0
              }
            ],
            product_vat_exclusive: {},
            product_vat_inclusive: {},
            type: '',
            type_description: '',
            type_description_translated: ''
          }
        ],
        id: 0,
        invoice_date: '',
        invoice_number: '',
        request_reference_split_the_bill: [{id: 0, type: ''}],
        status: '',
        total_vat: {},
        total_vat_exclusive: {},
        total_vat_inclusive: {},
        updated: '',
        vat_number: ''
      },
      DraftPayment: {
        entries: [
          {
            alias: {},
            amount: {},
            attachment: [{id: 0, monetary_account_id: 0}],
            counterparty_alias: {},
            description: '',
            id: 0,
            merchant_reference: '',
            type: ''
          }
        ],
        number_of_required_accepts: 0,
        previous_updated_timestamp: '',
        schedule: {
          object: {
            Payment: {
              address_billing: {},
              address_shipping: {},
              alias: {},
              allow_bunqto: false,
              amount: {},
              attachment: [{}],
              balance_after_mutation: {},
              batch_id: 0,
              bunqto_expiry: '',
              bunqto_share_url: '',
              bunqto_status: '',
              bunqto_sub_status: '',
              bunqto_time_responded: '',
              counterparty_alias: {},
              created: '',
              description: '',
              geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
              id: 0,
              merchant_reference: '',
              monetary_account_id: 0,
              payment_auto_allocate_instance: {
                created: '',
                error_message: [],
                id: 0,
                payment_auto_allocate_id: 0,
                payment_batch: {payments: {Payment: []}},
                payment_id: 0,
                status: '',
                updated: ''
              },
              request_reference_split_the_bill: [{}],
              scheduled_id: 0,
              sub_type: '',
              type: '',
              updated: ''
            },
            PaymentBatch: {}
          },
          recurrence_size: 0,
          recurrence_unit: '',
          status: '',
          time_end: '',
          time_start: ''
        },
        status: ''
      },
      MasterCardAction: {
        alias: {},
        all_mastercard_action_refund: [
          {
            additional_information: {
              attachment: [{id: 0}],
              category: '',
              comment: '',
              reason: '',
              terms_and_conditions: ''
            },
            alias: {},
            amount: {},
            attachment: [{}],
            category: '',
            comment: '',
            counterparty_alias: {},
            created: '',
            description: '',
            id: 0,
            label_card: {
              expiry_date: '',
              label_user: {},
              second_line: '',
              status: '',
              type: '',
              uuid: ''
            },
            label_user_creator: {},
            mastercard_action_id: 0,
            reason: '',
            reference_mastercard_action_event: [{event_id: 0}],
            status: '',
            status_description: '',
            status_description_translated: '',
            status_together_url: '',
            sub_type: '',
            terms_and_conditions: '',
            time_refund: '',
            type: '',
            updated: ''
          }
        ],
        amount_billing: {},
        amount_converted: {},
        amount_fee: {},
        amount_local: {},
        amount_original_billing: {},
        amount_original_local: {},
        applied_limit: '',
        authorisation_status: '',
        authorisation_type: '',
        card_authorisation_id_response: '',
        card_id: 0,
        city: '',
        clearing_expiry_time: '',
        clearing_status: '',
        counterparty_alias: {},
        decision: '',
        decision_description: '',
        decision_description_translated: '',
        decision_together_url: '',
        description: '',
        eligible_whitelist_id: 0,
        id: 0,
        label_card: {},
        maturity_date: '',
        monetary_account_id: 0,
        pan_entry_mode_user: '',
        payment_status: '',
        pos_card_holder_presence: '',
        pos_card_presence: '',
        request_reference_split_the_bill: [{}],
        reservation_expiry_time: '',
        secure_code_id: 0,
        settlement_status: '',
        token_status: '',
        wallet_provider_id: ''
      },
      Payment: {},
      PaymentBatch: {},
      RequestResponse: {
        address_billing: {},
        address_shipping: {},
        alias: {},
        amount_inquired: {},
        amount_responded: {},
        attachment: [{content_type: '', description: '', urls: [{type: '', url: ''}]}],
        counterparty_alias: {},
        created: '',
        credit_scheme_identifier: '',
        description: '',
        eligible_whitelist_id: 0,
        event_id: 0,
        geolocation: {},
        id: 0,
        mandate_identifier: '',
        minimum_age: 0,
        monetary_account_id: 0,
        redirect_url: '',
        request_reference_split_the_bill: [{}],
        require_address: '',
        status: '',
        sub_type: '',
        time_expiry: '',
        time_refund_requested: '',
        time_refunded: '',
        time_responded: '',
        type: '',
        updated: '',
        user_refund_requested: {}
      },
      ScheduleInstance: {
        error_message: [],
        request_reference_split_the_bill: [{}],
        result_object: {Payment: {}, PaymentBatch: {}},
        scheduled_object: {},
        state: '',
        time_end: '',
        time_start: ''
      },
      TransferwisePayment: {
        alias: {},
        amount_source: {},
        amount_target: {},
        counterparty_alias: {},
        monetary_account_id: '',
        pay_in_reference: '',
        quote: {
          amount_fee: {},
          amount_source: {},
          amount_target: {},
          created: '',
          currency_source: '',
          currency_target: '',
          id: 0,
          quote_id: '',
          rate: '',
          time_delivery_estimate: '',
          time_expiry: '',
          updated: ''
        },
        rate: '',
        recipient_id: '',
        reference: '',
        status: '',
        status_transferwise: '',
        status_transferwise_issue: '',
        sub_status: '',
        time_delivery_estimate: ''
      },
      WhitelistResult: {
        error_message: [],
        id: 0,
        monetary_account_paying_id: 0,
        object: {draftPayment: {}, id: 0, requestResponse: {}},
        request_reference_split_the_bill: [{}],
        status: '',
        sub_status: '',
        whitelist: {}
      }
    },
    request_inquiries: [
      {
        address_billing: {},
        address_shipping: {},
        allow_amount_higher: false,
        allow_amount_lower: false,
        allow_bunqme: false,
        amount_inquired: {},
        amount_responded: {},
        attachment: [{id: 0}],
        batch_id: 0,
        bunqme_share_url: '',
        counterparty_alias: {},
        created: '',
        description: '',
        event_id: 0,
        geolocation: {},
        id: 0,
        merchant_reference: '',
        minimum_age: 0,
        monetary_account_id: 0,
        redirect_url: '',
        reference_split_the_bill: {},
        require_address: '',
        scheduled_id: 0,
        status: '',
        time_expiry: '',
        time_responded: '',
        updated: '',
        user_alias_created: {},
        user_alias_revoked: {},
        want_tip: false
      }
    ],
    status: '',
    total_amount_inquired: {}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"event_id":0,"reference_split_the_bill":{"BillingInvoice":{"address":{"city":"","country":"","extra":"","house_number":"","is_user_address_updated":false,"mailbox_name":"","po_box":"","postal_code":"","province":"","street":""},"alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"category":"","chamber_of_commerce_number":"","counterparty_address":{},"counterparty_alias":{},"created":"","description":"","external_url":"","group":[{"instance_description":"","item":[{"billing_date":"","id":0,"quantity":0,"total_vat_exclusive":{"currency":"","value":""},"total_vat_inclusive":{},"type_description":"","type_description_translated":"","unit_vat_exclusive":{},"unit_vat_inclusive":{},"vat":0}],"product_vat_exclusive":{},"product_vat_inclusive":{},"type":"","type_description":"","type_description_translated":""}],"id":0,"invoice_date":"","invoice_number":"","request_reference_split_the_bill":[{"id":0,"type":""}],"status":"","total_vat":{},"total_vat_exclusive":{},"total_vat_inclusive":{},"updated":"","vat_number":""},"DraftPayment":{"entries":[{"alias":{},"amount":{},"attachment":[{"id":0,"monetary_account_id":0}],"counterparty_alias":{},"description":"","id":0,"merchant_reference":"","type":""}],"number_of_required_accepts":0,"previous_updated_timestamp":"","schedule":{"object":{"Payment":{"address_billing":{},"address_shipping":{},"alias":{},"allow_bunqto":false,"amount":{},"attachment":[{}],"balance_after_mutation":{},"batch_id":0,"bunqto_expiry":"","bunqto_share_url":"","bunqto_status":"","bunqto_sub_status":"","bunqto_time_responded":"","counterparty_alias":{},"created":"","description":"","geolocation":{"altitude":0,"latitude":0,"longitude":0,"radius":0},"id":0,"merchant_reference":"","monetary_account_id":0,"payment_auto_allocate_instance":{"created":"","error_message":[],"id":0,"payment_auto_allocate_id":0,"payment_batch":{"payments":{"Payment":[]}},"payment_id":0,"status":"","updated":""},"request_reference_split_the_bill":[{}],"scheduled_id":0,"sub_type":"","type":"","updated":""},"PaymentBatch":{}},"recurrence_size":0,"recurrence_unit":"","status":"","time_end":"","time_start":""},"status":""},"MasterCardAction":{"alias":{},"all_mastercard_action_refund":[{"additional_information":{"attachment":[{"id":0}],"category":"","comment":"","reason":"","terms_and_conditions":""},"alias":{},"amount":{},"attachment":[{}],"category":"","comment":"","counterparty_alias":{},"created":"","description":"","id":0,"label_card":{"expiry_date":"","label_user":{},"second_line":"","status":"","type":"","uuid":""},"label_user_creator":{},"mastercard_action_id":0,"reason":"","reference_mastercard_action_event":[{"event_id":0}],"status":"","status_description":"","status_description_translated":"","status_together_url":"","sub_type":"","terms_and_conditions":"","time_refund":"","type":"","updated":""}],"amount_billing":{},"amount_converted":{},"amount_fee":{},"amount_local":{},"amount_original_billing":{},"amount_original_local":{},"applied_limit":"","authorisation_status":"","authorisation_type":"","card_authorisation_id_response":"","card_id":0,"city":"","clearing_expiry_time":"","clearing_status":"","counterparty_alias":{},"decision":"","decision_description":"","decision_description_translated":"","decision_together_url":"","description":"","eligible_whitelist_id":0,"id":0,"label_card":{},"maturity_date":"","monetary_account_id":0,"pan_entry_mode_user":"","payment_status":"","pos_card_holder_presence":"","pos_card_presence":"","request_reference_split_the_bill":[{}],"reservation_expiry_time":"","secure_code_id":0,"settlement_status":"","token_status":"","wallet_provider_id":""},"Payment":{},"PaymentBatch":{},"RequestResponse":{"address_billing":{},"address_shipping":{},"alias":{},"amount_inquired":{},"amount_responded":{},"attachment":[{"content_type":"","description":"","urls":[{"type":"","url":""}]}],"counterparty_alias":{},"created":"","credit_scheme_identifier":"","description":"","eligible_whitelist_id":0,"event_id":0,"geolocation":{},"id":0,"mandate_identifier":"","minimum_age":0,"monetary_account_id":0,"redirect_url":"","request_reference_split_the_bill":[{}],"require_address":"","status":"","sub_type":"","time_expiry":"","time_refund_requested":"","time_refunded":"","time_responded":"","type":"","updated":"","user_refund_requested":{}},"ScheduleInstance":{"error_message":[],"request_reference_split_the_bill":[{}],"result_object":{"Payment":{},"PaymentBatch":{}},"scheduled_object":{},"state":"","time_end":"","time_start":""},"TransferwisePayment":{"alias":{},"amount_source":{},"amount_target":{},"counterparty_alias":{},"monetary_account_id":"","pay_in_reference":"","quote":{"amount_fee":{},"amount_source":{},"amount_target":{},"created":"","currency_source":"","currency_target":"","id":0,"quote_id":"","rate":"","time_delivery_estimate":"","time_expiry":"","updated":""},"rate":"","recipient_id":"","reference":"","status":"","status_transferwise":"","status_transferwise_issue":"","sub_status":"","time_delivery_estimate":""},"WhitelistResult":{"error_message":[],"id":0,"monetary_account_paying_id":0,"object":{"draftPayment":{},"id":0,"requestResponse":{}},"request_reference_split_the_bill":[{}],"status":"","sub_status":"","whitelist":{}}},"request_inquiries":[{"address_billing":{},"address_shipping":{},"allow_amount_higher":false,"allow_amount_lower":false,"allow_bunqme":false,"amount_inquired":{},"amount_responded":{},"attachment":[{"id":0}],"batch_id":0,"bunqme_share_url":"","counterparty_alias":{},"created":"","description":"","event_id":0,"geolocation":{},"id":0,"merchant_reference":"","minimum_age":0,"monetary_account_id":0,"redirect_url":"","reference_split_the_bill":{},"require_address":"","scheduled_id":0,"status":"","time_expiry":"","time_responded":"","updated":"","user_alias_created":{},"user_alias_revoked":{},"want_tip":false}],"status":"","total_amount_inquired":{}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"event_id": @0,
                              @"reference_split_the_bill": @{ @"BillingInvoice": @{ @"address": @{ @"city": @"", @"country": @"", @"extra": @"", @"house_number": @"", @"is_user_address_updated": @NO, @"mailbox_name": @"", @"po_box": @"", @"postal_code": @"", @"province": @"", @"street": @"" }, @"alias": @{ @"avatar": @{ @"anchor_uuid": @"", @"image": @[ @{ @"attachment_public_uuid": @"", @"content_type": @"", @"height": @0, @"width": @0 } ], @"style": @"", @"uuid": @"" }, @"bunq_me": @{ @"name": @"", @"service": @"", @"type": @"", @"value": @"" }, @"country": @"", @"display_name": @"", @"iban": @"", @"is_light": @NO, @"label_user": @{ @"avatar": @{  }, @"country": @"", @"display_name": @"", @"public_nick_name": @"", @"uuid": @"" }, @"merchant_category_code": @"", @"swift_account_number": @"", @"swift_bic": @"", @"transferwise_account_number": @"", @"transferwise_bank_code": @"" }, @"category": @"", @"chamber_of_commerce_number": @"", @"counterparty_address": @{  }, @"counterparty_alias": @{  }, @"created": @"", @"description": @"", @"external_url": @"", @"group": @[ @{ @"instance_description": @"", @"item": @[ @{ @"billing_date": @"", @"id": @0, @"quantity": @0, @"total_vat_exclusive": @{ @"currency": @"", @"value": @"" }, @"total_vat_inclusive": @{  }, @"type_description": @"", @"type_description_translated": @"", @"unit_vat_exclusive": @{  }, @"unit_vat_inclusive": @{  }, @"vat": @0 } ], @"product_vat_exclusive": @{  }, @"product_vat_inclusive": @{  }, @"type": @"", @"type_description": @"", @"type_description_translated": @"" } ], @"id": @0, @"invoice_date": @"", @"invoice_number": @"", @"request_reference_split_the_bill": @[ @{ @"id": @0, @"type": @"" } ], @"status": @"", @"total_vat": @{  }, @"total_vat_exclusive": @{  }, @"total_vat_inclusive": @{  }, @"updated": @"", @"vat_number": @"" }, @"DraftPayment": @{ @"entries": @[ @{ @"alias": @{  }, @"amount": @{  }, @"attachment": @[ @{ @"id": @0, @"monetary_account_id": @0 } ], @"counterparty_alias": @{  }, @"description": @"", @"id": @0, @"merchant_reference": @"", @"type": @"" } ], @"number_of_required_accepts": @0, @"previous_updated_timestamp": @"", @"schedule": @{ @"object": @{ @"Payment": @{ @"address_billing": @{  }, @"address_shipping": @{  }, @"alias": @{  }, @"allow_bunqto": @NO, @"amount": @{  }, @"attachment": @[ @{  } ], @"balance_after_mutation": @{  }, @"batch_id": @0, @"bunqto_expiry": @"", @"bunqto_share_url": @"", @"bunqto_status": @"", @"bunqto_sub_status": @"", @"bunqto_time_responded": @"", @"counterparty_alias": @{  }, @"created": @"", @"description": @"", @"geolocation": @{ @"altitude": @0, @"latitude": @0, @"longitude": @0, @"radius": @0 }, @"id": @0, @"merchant_reference": @"", @"monetary_account_id": @0, @"payment_auto_allocate_instance": @{ @"created": @"", @"error_message": @[  ], @"id": @0, @"payment_auto_allocate_id": @0, @"payment_batch": @{ @"payments": @{ @"Payment": @[  ] } }, @"payment_id": @0, @"status": @"", @"updated": @"" }, @"request_reference_split_the_bill": @[ @{  } ], @"scheduled_id": @0, @"sub_type": @"", @"type": @"", @"updated": @"" }, @"PaymentBatch": @{  } }, @"recurrence_size": @0, @"recurrence_unit": @"", @"status": @"", @"time_end": @"", @"time_start": @"" }, @"status": @"" }, @"MasterCardAction": @{ @"alias": @{  }, @"all_mastercard_action_refund": @[ @{ @"additional_information": @{ @"attachment": @[ @{ @"id": @0 } ], @"category": @"", @"comment": @"", @"reason": @"", @"terms_and_conditions": @"" }, @"alias": @{  }, @"amount": @{  }, @"attachment": @[ @{  } ], @"category": @"", @"comment": @"", @"counterparty_alias": @{  }, @"created": @"", @"description": @"", @"id": @0, @"label_card": @{ @"expiry_date": @"", @"label_user": @{  }, @"second_line": @"", @"status": @"", @"type": @"", @"uuid": @"" }, @"label_user_creator": @{  }, @"mastercard_action_id": @0, @"reason": @"", @"reference_mastercard_action_event": @[ @{ @"event_id": @0 } ], @"status": @"", @"status_description": @"", @"status_description_translated": @"", @"status_together_url": @"", @"sub_type": @"", @"terms_and_conditions": @"", @"time_refund": @"", @"type": @"", @"updated": @"" } ], @"amount_billing": @{  }, @"amount_converted": @{  }, @"amount_fee": @{  }, @"amount_local": @{  }, @"amount_original_billing": @{  }, @"amount_original_local": @{  }, @"applied_limit": @"", @"authorisation_status": @"", @"authorisation_type": @"", @"card_authorisation_id_response": @"", @"card_id": @0, @"city": @"", @"clearing_expiry_time": @"", @"clearing_status": @"", @"counterparty_alias": @{  }, @"decision": @"", @"decision_description": @"", @"decision_description_translated": @"", @"decision_together_url": @"", @"description": @"", @"eligible_whitelist_id": @0, @"id": @0, @"label_card": @{  }, @"maturity_date": @"", @"monetary_account_id": @0, @"pan_entry_mode_user": @"", @"payment_status": @"", @"pos_card_holder_presence": @"", @"pos_card_presence": @"", @"request_reference_split_the_bill": @[ @{  } ], @"reservation_expiry_time": @"", @"secure_code_id": @0, @"settlement_status": @"", @"token_status": @"", @"wallet_provider_id": @"" }, @"Payment": @{  }, @"PaymentBatch": @{  }, @"RequestResponse": @{ @"address_billing": @{  }, @"address_shipping": @{  }, @"alias": @{  }, @"amount_inquired": @{  }, @"amount_responded": @{  }, @"attachment": @[ @{ @"content_type": @"", @"description": @"", @"urls": @[ @{ @"type": @"", @"url": @"" } ] } ], @"counterparty_alias": @{  }, @"created": @"", @"credit_scheme_identifier": @"", @"description": @"", @"eligible_whitelist_id": @0, @"event_id": @0, @"geolocation": @{  }, @"id": @0, @"mandate_identifier": @"", @"minimum_age": @0, @"monetary_account_id": @0, @"redirect_url": @"", @"request_reference_split_the_bill": @[ @{  } ], @"require_address": @"", @"status": @"", @"sub_type": @"", @"time_expiry": @"", @"time_refund_requested": @"", @"time_refunded": @"", @"time_responded": @"", @"type": @"", @"updated": @"", @"user_refund_requested": @{  } }, @"ScheduleInstance": @{ @"error_message": @[  ], @"request_reference_split_the_bill": @[ @{  } ], @"result_object": @{ @"Payment": @{  }, @"PaymentBatch": @{  } }, @"scheduled_object": @{  }, @"state": @"", @"time_end": @"", @"time_start": @"" }, @"TransferwisePayment": @{ @"alias": @{  }, @"amount_source": @{  }, @"amount_target": @{  }, @"counterparty_alias": @{  }, @"monetary_account_id": @"", @"pay_in_reference": @"", @"quote": @{ @"amount_fee": @{  }, @"amount_source": @{  }, @"amount_target": @{  }, @"created": @"", @"currency_source": @"", @"currency_target": @"", @"id": @0, @"quote_id": @"", @"rate": @"", @"time_delivery_estimate": @"", @"time_expiry": @"", @"updated": @"" }, @"rate": @"", @"recipient_id": @"", @"reference": @"", @"status": @"", @"status_transferwise": @"", @"status_transferwise_issue": @"", @"sub_status": @"", @"time_delivery_estimate": @"" }, @"WhitelistResult": @{ @"error_message": @[  ], @"id": @0, @"monetary_account_paying_id": @0, @"object": @{ @"draftPayment": @{  }, @"id": @0, @"requestResponse": @{  } }, @"request_reference_split_the_bill": @[ @{  } ], @"status": @"", @"sub_status": @"", @"whitelist": @{  } } },
                              @"request_inquiries": @[ @{ @"address_billing": @{  }, @"address_shipping": @{  }, @"allow_amount_higher": @NO, @"allow_amount_lower": @NO, @"allow_bunqme": @NO, @"amount_inquired": @{  }, @"amount_responded": @{  }, @"attachment": @[ @{ @"id": @0 } ], @"batch_id": @0, @"bunqme_share_url": @"", @"counterparty_alias": @{  }, @"created": @"", @"description": @"", @"event_id": @0, @"geolocation": @{  }, @"id": @0, @"merchant_reference": @"", @"minimum_age": @0, @"monetary_account_id": @0, @"redirect_url": @"", @"reference_split_the_bill": @{  }, @"require_address": @"", @"scheduled_id": @0, @"status": @"", @"time_expiry": @"", @"time_responded": @"", @"updated": @"", @"user_alias_created": @{  }, @"user_alias_revoked": @{  }, @"want_tip": @NO } ],
                              @"status": @"",
                              @"total_amount_inquired": @{  } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"event_id\": 0,\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {\n                \"currency\": \"\",\n                \"value\": \"\"\n              },\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {\n              \"altitude\": 0,\n              \"latitude\": 0,\n              \"longitude\": 0,\n              \"radius\": 0\n            },\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"request_inquiries\": [\n    {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"allow_amount_higher\": false,\n      \"allow_amount_lower\": false,\n      \"allow_bunqme\": false,\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"id\": 0\n        }\n      ],\n      \"batch_id\": 0,\n      \"bunqme_share_url\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"reference_split_the_bill\": {},\n      \"require_address\": \"\",\n      \"scheduled_id\": 0,\n      \"status\": \"\",\n      \"time_expiry\": \"\",\n      \"time_responded\": \"\",\n      \"updated\": \"\",\n      \"user_alias_created\": {},\n      \"user_alias_revoked\": {},\n      \"want_tip\": false\n    }\n  ],\n  \"status\": \"\",\n  \"total_amount_inquired\": {}\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'event_id' => 0,
    'reference_split_the_bill' => [
        'BillingInvoice' => [
                'address' => [
                                'city' => '',
                                'country' => '',
                                'extra' => '',
                                'house_number' => '',
                                'is_user_address_updated' => null,
                                'mailbox_name' => '',
                                'po_box' => '',
                                'postal_code' => '',
                                'province' => '',
                                'street' => ''
                ],
                'alias' => [
                                'avatar' => [
                                                                'anchor_uuid' => '',
                                                                'image' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'attachment_public_uuid' => '',
                                                                                                                                                                                                                                                                'content_type' => '',
                                                                                                                                                                                                                                                                'height' => 0,
                                                                                                                                                                                                                                                                'width' => 0
                                                                                                                                ]
                                                                ],
                                                                'style' => '',
                                                                'uuid' => ''
                                ],
                                'bunq_me' => [
                                                                'name' => '',
                                                                'service' => '',
                                                                'type' => '',
                                                                'value' => ''
                                ],
                                'country' => '',
                                'display_name' => '',
                                'iban' => '',
                                'is_light' => null,
                                'label_user' => [
                                                                'avatar' => [
                                                                                                                                
                                                                ],
                                                                'country' => '',
                                                                'display_name' => '',
                                                                'public_nick_name' => '',
                                                                'uuid' => ''
                                ],
                                'merchant_category_code' => '',
                                'swift_account_number' => '',
                                'swift_bic' => '',
                                'transferwise_account_number' => '',
                                'transferwise_bank_code' => ''
                ],
                'category' => '',
                'chamber_of_commerce_number' => '',
                'counterparty_address' => [
                                
                ],
                'counterparty_alias' => [
                                
                ],
                'created' => '',
                'description' => '',
                'external_url' => '',
                'group' => [
                                [
                                                                'instance_description' => '',
                                                                'item' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'billing_date' => '',
                                                                                                                                                                                                                                                                'id' => 0,
                                                                                                                                                                                                                                                                'quantity' => 0,
                                                                                                                                                                                                                                                                'total_vat_exclusive' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'currency' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'value' => ''
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'total_vat_inclusive' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'type_description' => '',
                                                                                                                                                                                                                                                                'type_description_translated' => '',
                                                                                                                                                                                                                                                                'unit_vat_exclusive' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'unit_vat_inclusive' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'vat' => 0
                                                                                                                                ]
                                                                ],
                                                                'product_vat_exclusive' => [
                                                                                                                                
                                                                ],
                                                                'product_vat_inclusive' => [
                                                                                                                                
                                                                ],
                                                                'type' => '',
                                                                'type_description' => '',
                                                                'type_description_translated' => ''
                                ]
                ],
                'id' => 0,
                'invoice_date' => '',
                'invoice_number' => '',
                'request_reference_split_the_bill' => [
                                [
                                                                'id' => 0,
                                                                'type' => ''
                                ]
                ],
                'status' => '',
                'total_vat' => [
                                
                ],
                'total_vat_exclusive' => [
                                
                ],
                'total_vat_inclusive' => [
                                
                ],
                'updated' => '',
                'vat_number' => ''
        ],
        'DraftPayment' => [
                'entries' => [
                                [
                                                                'alias' => [
                                                                                                                                
                                                                ],
                                                                'amount' => [
                                                                                                                                
                                                                ],
                                                                'attachment' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'id' => 0,
                                                                                                                                                                                                                                                                'monetary_account_id' => 0
                                                                                                                                ]
                                                                ],
                                                                'counterparty_alias' => [
                                                                                                                                
                                                                ],
                                                                'description' => '',
                                                                'id' => 0,
                                                                'merchant_reference' => '',
                                                                'type' => ''
                                ]
                ],
                'number_of_required_accepts' => 0,
                'previous_updated_timestamp' => '',
                'schedule' => [
                                'object' => [
                                                                'Payment' => [
                                                                                                                                'address_billing' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'address_shipping' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'alias' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'allow_bunqto' => null,
                                                                                                                                'amount' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'attachment' => [
                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'balance_after_mutation' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'batch_id' => 0,
                                                                                                                                'bunqto_expiry' => '',
                                                                                                                                'bunqto_share_url' => '',
                                                                                                                                'bunqto_status' => '',
                                                                                                                                'bunqto_sub_status' => '',
                                                                                                                                'bunqto_time_responded' => '',
                                                                                                                                'counterparty_alias' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'created' => '',
                                                                                                                                'description' => '',
                                                                                                                                'geolocation' => [
                                                                                                                                                                                                                                                                'altitude' => 0,
                                                                                                                                                                                                                                                                'latitude' => 0,
                                                                                                                                                                                                                                                                'longitude' => 0,
                                                                                                                                                                                                                                                                'radius' => 0
                                                                                                                                ],
                                                                                                                                'id' => 0,
                                                                                                                                'merchant_reference' => '',
                                                                                                                                'monetary_account_id' => 0,
                                                                                                                                'payment_auto_allocate_instance' => [
                                                                                                                                                                                                                                                                'created' => '',
                                                                                                                                                                                                                                                                'error_message' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'id' => 0,
                                                                                                                                                                                                                                                                'payment_auto_allocate_id' => 0,
                                                                                                                                                                                                                                                                'payment_batch' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'payments' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'Payment' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'payment_id' => 0,
                                                                                                                                                                                                                                                                'status' => '',
                                                                                                                                                                                                                                                                'updated' => ''
                                                                                                                                ],
                                                                                                                                'request_reference_split_the_bill' => [
                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'scheduled_id' => 0,
                                                                                                                                'sub_type' => '',
                                                                                                                                'type' => '',
                                                                                                                                'updated' => ''
                                                                ],
                                                                'PaymentBatch' => [
                                                                                                                                
                                                                ]
                                ],
                                'recurrence_size' => 0,
                                'recurrence_unit' => '',
                                'status' => '',
                                'time_end' => '',
                                'time_start' => ''
                ],
                'status' => ''
        ],
        'MasterCardAction' => [
                'alias' => [
                                
                ],
                'all_mastercard_action_refund' => [
                                [
                                                                'additional_information' => [
                                                                                                                                'attachment' => [
                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'id' => 0
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'category' => '',
                                                                                                                                'comment' => '',
                                                                                                                                'reason' => '',
                                                                                                                                'terms_and_conditions' => ''
                                                                ],
                                                                'alias' => [
                                                                                                                                
                                                                ],
                                                                'amount' => [
                                                                                                                                
                                                                ],
                                                                'attachment' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'category' => '',
                                                                'comment' => '',
                                                                'counterparty_alias' => [
                                                                                                                                
                                                                ],
                                                                'created' => '',
                                                                'description' => '',
                                                                'id' => 0,
                                                                'label_card' => [
                                                                                                                                'expiry_date' => '',
                                                                                                                                'label_user' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'second_line' => '',
                                                                                                                                'status' => '',
                                                                                                                                'type' => '',
                                                                                                                                'uuid' => ''
                                                                ],
                                                                'label_user_creator' => [
                                                                                                                                
                                                                ],
                                                                'mastercard_action_id' => 0,
                                                                'reason' => '',
                                                                'reference_mastercard_action_event' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'event_id' => 0
                                                                                                                                ]
                                                                ],
                                                                'status' => '',
                                                                'status_description' => '',
                                                                'status_description_translated' => '',
                                                                'status_together_url' => '',
                                                                'sub_type' => '',
                                                                'terms_and_conditions' => '',
                                                                'time_refund' => '',
                                                                'type' => '',
                                                                'updated' => ''
                                ]
                ],
                'amount_billing' => [
                                
                ],
                'amount_converted' => [
                                
                ],
                'amount_fee' => [
                                
                ],
                'amount_local' => [
                                
                ],
                'amount_original_billing' => [
                                
                ],
                'amount_original_local' => [
                                
                ],
                'applied_limit' => '',
                'authorisation_status' => '',
                'authorisation_type' => '',
                'card_authorisation_id_response' => '',
                'card_id' => 0,
                'city' => '',
                'clearing_expiry_time' => '',
                'clearing_status' => '',
                'counterparty_alias' => [
                                
                ],
                'decision' => '',
                'decision_description' => '',
                'decision_description_translated' => '',
                'decision_together_url' => '',
                'description' => '',
                'eligible_whitelist_id' => 0,
                'id' => 0,
                'label_card' => [
                                
                ],
                'maturity_date' => '',
                'monetary_account_id' => 0,
                'pan_entry_mode_user' => '',
                'payment_status' => '',
                'pos_card_holder_presence' => '',
                'pos_card_presence' => '',
                'request_reference_split_the_bill' => [
                                [
                                                                
                                ]
                ],
                'reservation_expiry_time' => '',
                'secure_code_id' => 0,
                'settlement_status' => '',
                'token_status' => '',
                'wallet_provider_id' => ''
        ],
        'Payment' => [
                
        ],
        'PaymentBatch' => [
                
        ],
        'RequestResponse' => [
                'address_billing' => [
                                
                ],
                'address_shipping' => [
                                
                ],
                'alias' => [
                                
                ],
                'amount_inquired' => [
                                
                ],
                'amount_responded' => [
                                
                ],
                'attachment' => [
                                [
                                                                'content_type' => '',
                                                                'description' => '',
                                                                'urls' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'type' => '',
                                                                                                                                                                                                                                                                'url' => ''
                                                                                                                                ]
                                                                ]
                                ]
                ],
                'counterparty_alias' => [
                                
                ],
                'created' => '',
                'credit_scheme_identifier' => '',
                'description' => '',
                'eligible_whitelist_id' => 0,
                'event_id' => 0,
                'geolocation' => [
                                
                ],
                'id' => 0,
                'mandate_identifier' => '',
                'minimum_age' => 0,
                'monetary_account_id' => 0,
                'redirect_url' => '',
                'request_reference_split_the_bill' => [
                                [
                                                                
                                ]
                ],
                'require_address' => '',
                'status' => '',
                'sub_type' => '',
                'time_expiry' => '',
                'time_refund_requested' => '',
                'time_refunded' => '',
                'time_responded' => '',
                'type' => '',
                'updated' => '',
                'user_refund_requested' => [
                                
                ]
        ],
        'ScheduleInstance' => [
                'error_message' => [
                                
                ],
                'request_reference_split_the_bill' => [
                                [
                                                                
                                ]
                ],
                'result_object' => [
                                'Payment' => [
                                                                
                                ],
                                'PaymentBatch' => [
                                                                
                                ]
                ],
                'scheduled_object' => [
                                
                ],
                'state' => '',
                'time_end' => '',
                'time_start' => ''
        ],
        'TransferwisePayment' => [
                'alias' => [
                                
                ],
                'amount_source' => [
                                
                ],
                'amount_target' => [
                                
                ],
                'counterparty_alias' => [
                                
                ],
                'monetary_account_id' => '',
                'pay_in_reference' => '',
                'quote' => [
                                'amount_fee' => [
                                                                
                                ],
                                'amount_source' => [
                                                                
                                ],
                                'amount_target' => [
                                                                
                                ],
                                'created' => '',
                                'currency_source' => '',
                                'currency_target' => '',
                                'id' => 0,
                                'quote_id' => '',
                                'rate' => '',
                                'time_delivery_estimate' => '',
                                'time_expiry' => '',
                                'updated' => ''
                ],
                'rate' => '',
                'recipient_id' => '',
                'reference' => '',
                'status' => '',
                'status_transferwise' => '',
                'status_transferwise_issue' => '',
                'sub_status' => '',
                'time_delivery_estimate' => ''
        ],
        'WhitelistResult' => [
                'error_message' => [
                                
                ],
                'id' => 0,
                'monetary_account_paying_id' => 0,
                'object' => [
                                'draftPayment' => [
                                                                
                                ],
                                'id' => 0,
                                'requestResponse' => [
                                                                
                                ]
                ],
                'request_reference_split_the_bill' => [
                                [
                                                                
                                ]
                ],
                'status' => '',
                'sub_status' => '',
                'whitelist' => [
                                
                ]
        ]
    ],
    'request_inquiries' => [
        [
                'address_billing' => [
                                
                ],
                'address_shipping' => [
                                
                ],
                'allow_amount_higher' => null,
                'allow_amount_lower' => null,
                'allow_bunqme' => null,
                'amount_inquired' => [
                                
                ],
                'amount_responded' => [
                                
                ],
                'attachment' => [
                                [
                                                                'id' => 0
                                ]
                ],
                'batch_id' => 0,
                'bunqme_share_url' => '',
                'counterparty_alias' => [
                                
                ],
                'created' => '',
                'description' => '',
                'event_id' => 0,
                'geolocation' => [
                                
                ],
                'id' => 0,
                'merchant_reference' => '',
                'minimum_age' => 0,
                'monetary_account_id' => 0,
                'redirect_url' => '',
                'reference_split_the_bill' => [
                                
                ],
                'require_address' => '',
                'scheduled_id' => 0,
                'status' => '',
                'time_expiry' => '',
                'time_responded' => '',
                'updated' => '',
                'user_alias_created' => [
                                
                ],
                'user_alias_revoked' => [
                                
                ],
                'want_tip' => null
        ]
    ],
    'status' => '',
    'total_amount_inquired' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch', [
  'body' => '{
  "event_id": 0,
  "reference_split_the_bill": {
    "BillingInvoice": {
      "address": {
        "city": "",
        "country": "",
        "extra": "",
        "house_number": "",
        "is_user_address_updated": false,
        "mailbox_name": "",
        "po_box": "",
        "postal_code": "",
        "province": "",
        "street": ""
      },
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "category": "",
      "chamber_of_commerce_number": "",
      "counterparty_address": {},
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "external_url": "",
      "group": [
        {
          "instance_description": "",
          "item": [
            {
              "billing_date": "",
              "id": 0,
              "quantity": 0,
              "total_vat_exclusive": {
                "currency": "",
                "value": ""
              },
              "total_vat_inclusive": {},
              "type_description": "",
              "type_description_translated": "",
              "unit_vat_exclusive": {},
              "unit_vat_inclusive": {},
              "vat": 0
            }
          ],
          "product_vat_exclusive": {},
          "product_vat_inclusive": {},
          "type": "",
          "type_description": "",
          "type_description_translated": ""
        }
      ],
      "id": 0,
      "invoice_date": "",
      "invoice_number": "",
      "request_reference_split_the_bill": [
        {
          "id": 0,
          "type": ""
        }
      ],
      "status": "",
      "total_vat": {},
      "total_vat_exclusive": {},
      "total_vat_inclusive": {},
      "updated": "",
      "vat_number": ""
    },
    "DraftPayment": {
      "entries": [
        {
          "alias": {},
          "amount": {},
          "attachment": [
            {
              "id": 0,
              "monetary_account_id": 0
            }
          ],
          "counterparty_alias": {},
          "description": "",
          "id": 0,
          "merchant_reference": "",
          "type": ""
        }
      ],
      "number_of_required_accepts": 0,
      "previous_updated_timestamp": "",
      "schedule": {
        "object": {
          "Payment": {
            "address_billing": {},
            "address_shipping": {},
            "alias": {},
            "allow_bunqto": false,
            "amount": {},
            "attachment": [
              {}
            ],
            "balance_after_mutation": {},
            "batch_id": 0,
            "bunqto_expiry": "",
            "bunqto_share_url": "",
            "bunqto_status": "",
            "bunqto_sub_status": "",
            "bunqto_time_responded": "",
            "counterparty_alias": {},
            "created": "",
            "description": "",
            "geolocation": {
              "altitude": 0,
              "latitude": 0,
              "longitude": 0,
              "radius": 0
            },
            "id": 0,
            "merchant_reference": "",
            "monetary_account_id": 0,
            "payment_auto_allocate_instance": {
              "created": "",
              "error_message": [],
              "id": 0,
              "payment_auto_allocate_id": 0,
              "payment_batch": {
                "payments": {
                  "Payment": []
                }
              },
              "payment_id": 0,
              "status": "",
              "updated": ""
            },
            "request_reference_split_the_bill": [
              {}
            ],
            "scheduled_id": 0,
            "sub_type": "",
            "type": "",
            "updated": ""
          },
          "PaymentBatch": {}
        },
        "recurrence_size": 0,
        "recurrence_unit": "",
        "status": "",
        "time_end": "",
        "time_start": ""
      },
      "status": ""
    },
    "MasterCardAction": {
      "alias": {},
      "all_mastercard_action_refund": [
        {
          "additional_information": {
            "attachment": [
              {
                "id": 0
              }
            ],
            "category": "",
            "comment": "",
            "reason": "",
            "terms_and_conditions": ""
          },
          "alias": {},
          "amount": {},
          "attachment": [
            {}
          ],
          "category": "",
          "comment": "",
          "counterparty_alias": {},
          "created": "",
          "description": "",
          "id": 0,
          "label_card": {
            "expiry_date": "",
            "label_user": {},
            "second_line": "",
            "status": "",
            "type": "",
            "uuid": ""
          },
          "label_user_creator": {},
          "mastercard_action_id": 0,
          "reason": "",
          "reference_mastercard_action_event": [
            {
              "event_id": 0
            }
          ],
          "status": "",
          "status_description": "",
          "status_description_translated": "",
          "status_together_url": "",
          "sub_type": "",
          "terms_and_conditions": "",
          "time_refund": "",
          "type": "",
          "updated": ""
        }
      ],
      "amount_billing": {},
      "amount_converted": {},
      "amount_fee": {},
      "amount_local": {},
      "amount_original_billing": {},
      "amount_original_local": {},
      "applied_limit": "",
      "authorisation_status": "",
      "authorisation_type": "",
      "card_authorisation_id_response": "",
      "card_id": 0,
      "city": "",
      "clearing_expiry_time": "",
      "clearing_status": "",
      "counterparty_alias": {},
      "decision": "",
      "decision_description": "",
      "decision_description_translated": "",
      "decision_together_url": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "id": 0,
      "label_card": {},
      "maturity_date": "",
      "monetary_account_id": 0,
      "pan_entry_mode_user": "",
      "payment_status": "",
      "pos_card_holder_presence": "",
      "pos_card_presence": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "reservation_expiry_time": "",
      "secure_code_id": 0,
      "settlement_status": "",
      "token_status": "",
      "wallet_provider_id": ""
    },
    "Payment": {},
    "PaymentBatch": {},
    "RequestResponse": {
      "address_billing": {},
      "address_shipping": {},
      "alias": {},
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "content_type": "",
          "description": "",
          "urls": [
            {
              "type": "",
              "url": ""
            }
          ]
        }
      ],
      "counterparty_alias": {},
      "created": "",
      "credit_scheme_identifier": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "mandate_identifier": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "require_address": "",
      "status": "",
      "sub_type": "",
      "time_expiry": "",
      "time_refund_requested": "",
      "time_refunded": "",
      "time_responded": "",
      "type": "",
      "updated": "",
      "user_refund_requested": {}
    },
    "ScheduleInstance": {
      "error_message": [],
      "request_reference_split_the_bill": [
        {}
      ],
      "result_object": {
        "Payment": {},
        "PaymentBatch": {}
      },
      "scheduled_object": {},
      "state": "",
      "time_end": "",
      "time_start": ""
    },
    "TransferwisePayment": {
      "alias": {},
      "amount_source": {},
      "amount_target": {},
      "counterparty_alias": {},
      "monetary_account_id": "",
      "pay_in_reference": "",
      "quote": {
        "amount_fee": {},
        "amount_source": {},
        "amount_target": {},
        "created": "",
        "currency_source": "",
        "currency_target": "",
        "id": 0,
        "quote_id": "",
        "rate": "",
        "time_delivery_estimate": "",
        "time_expiry": "",
        "updated": ""
      },
      "rate": "",
      "recipient_id": "",
      "reference": "",
      "status": "",
      "status_transferwise": "",
      "status_transferwise_issue": "",
      "sub_status": "",
      "time_delivery_estimate": ""
    },
    "WhitelistResult": {
      "error_message": [],
      "id": 0,
      "monetary_account_paying_id": 0,
      "object": {
        "draftPayment": {},
        "id": 0,
        "requestResponse": {}
      },
      "request_reference_split_the_bill": [
        {}
      ],
      "status": "",
      "sub_status": "",
      "whitelist": {}
    }
  },
  "request_inquiries": [
    {
      "address_billing": {},
      "address_shipping": {},
      "allow_amount_higher": false,
      "allow_amount_lower": false,
      "allow_bunqme": false,
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "id": 0
        }
      ],
      "batch_id": 0,
      "bunqme_share_url": "",
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "merchant_reference": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "reference_split_the_bill": {},
      "require_address": "",
      "scheduled_id": 0,
      "status": "",
      "time_expiry": "",
      "time_responded": "",
      "updated": "",
      "user_alias_created": {},
      "user_alias_revoked": {},
      "want_tip": false
    }
  ],
  "status": "",
  "total_amount_inquired": {}
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'event_id' => 0,
  'reference_split_the_bill' => [
    'BillingInvoice' => [
        'address' => [
                'city' => '',
                'country' => '',
                'extra' => '',
                'house_number' => '',
                'is_user_address_updated' => null,
                'mailbox_name' => '',
                'po_box' => '',
                'postal_code' => '',
                'province' => '',
                'street' => ''
        ],
        'alias' => [
                'avatar' => [
                                'anchor_uuid' => '',
                                'image' => [
                                                                [
                                                                                                                                'attachment_public_uuid' => '',
                                                                                                                                'content_type' => '',
                                                                                                                                'height' => 0,
                                                                                                                                'width' => 0
                                                                ]
                                ],
                                'style' => '',
                                'uuid' => ''
                ],
                'bunq_me' => [
                                'name' => '',
                                'service' => '',
                                'type' => '',
                                'value' => ''
                ],
                'country' => '',
                'display_name' => '',
                'iban' => '',
                'is_light' => null,
                'label_user' => [
                                'avatar' => [
                                                                
                                ],
                                'country' => '',
                                'display_name' => '',
                                'public_nick_name' => '',
                                'uuid' => ''
                ],
                'merchant_category_code' => '',
                'swift_account_number' => '',
                'swift_bic' => '',
                'transferwise_account_number' => '',
                'transferwise_bank_code' => ''
        ],
        'category' => '',
        'chamber_of_commerce_number' => '',
        'counterparty_address' => [
                
        ],
        'counterparty_alias' => [
                
        ],
        'created' => '',
        'description' => '',
        'external_url' => '',
        'group' => [
                [
                                'instance_description' => '',
                                'item' => [
                                                                [
                                                                                                                                'billing_date' => '',
                                                                                                                                'id' => 0,
                                                                                                                                'quantity' => 0,
                                                                                                                                'total_vat_exclusive' => [
                                                                                                                                                                                                                                                                'currency' => '',
                                                                                                                                                                                                                                                                'value' => ''
                                                                                                                                ],
                                                                                                                                'total_vat_inclusive' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'type_description' => '',
                                                                                                                                'type_description_translated' => '',
                                                                                                                                'unit_vat_exclusive' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'unit_vat_inclusive' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'vat' => 0
                                                                ]
                                ],
                                'product_vat_exclusive' => [
                                                                
                                ],
                                'product_vat_inclusive' => [
                                                                
                                ],
                                'type' => '',
                                'type_description' => '',
                                'type_description_translated' => ''
                ]
        ],
        'id' => 0,
        'invoice_date' => '',
        'invoice_number' => '',
        'request_reference_split_the_bill' => [
                [
                                'id' => 0,
                                'type' => ''
                ]
        ],
        'status' => '',
        'total_vat' => [
                
        ],
        'total_vat_exclusive' => [
                
        ],
        'total_vat_inclusive' => [
                
        ],
        'updated' => '',
        'vat_number' => ''
    ],
    'DraftPayment' => [
        'entries' => [
                [
                                'alias' => [
                                                                
                                ],
                                'amount' => [
                                                                
                                ],
                                'attachment' => [
                                                                [
                                                                                                                                'id' => 0,
                                                                                                                                'monetary_account_id' => 0
                                                                ]
                                ],
                                'counterparty_alias' => [
                                                                
                                ],
                                'description' => '',
                                'id' => 0,
                                'merchant_reference' => '',
                                'type' => ''
                ]
        ],
        'number_of_required_accepts' => 0,
        'previous_updated_timestamp' => '',
        'schedule' => [
                'object' => [
                                'Payment' => [
                                                                'address_billing' => [
                                                                                                                                
                                                                ],
                                                                'address_shipping' => [
                                                                                                                                
                                                                ],
                                                                'alias' => [
                                                                                                                                
                                                                ],
                                                                'allow_bunqto' => null,
                                                                'amount' => [
                                                                                                                                
                                                                ],
                                                                'attachment' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'balance_after_mutation' => [
                                                                                                                                
                                                                ],
                                                                'batch_id' => 0,
                                                                'bunqto_expiry' => '',
                                                                'bunqto_share_url' => '',
                                                                'bunqto_status' => '',
                                                                'bunqto_sub_status' => '',
                                                                'bunqto_time_responded' => '',
                                                                'counterparty_alias' => [
                                                                                                                                
                                                                ],
                                                                'created' => '',
                                                                'description' => '',
                                                                'geolocation' => [
                                                                                                                                'altitude' => 0,
                                                                                                                                'latitude' => 0,
                                                                                                                                'longitude' => 0,
                                                                                                                                'radius' => 0
                                                                ],
                                                                'id' => 0,
                                                                'merchant_reference' => '',
                                                                'monetary_account_id' => 0,
                                                                'payment_auto_allocate_instance' => [
                                                                                                                                'created' => '',
                                                                                                                                'error_message' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'id' => 0,
                                                                                                                                'payment_auto_allocate_id' => 0,
                                                                                                                                'payment_batch' => [
                                                                                                                                                                                                                                                                'payments' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'Payment' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'payment_id' => 0,
                                                                                                                                'status' => '',
                                                                                                                                'updated' => ''
                                                                ],
                                                                'request_reference_split_the_bill' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'scheduled_id' => 0,
                                                                'sub_type' => '',
                                                                'type' => '',
                                                                'updated' => ''
                                ],
                                'PaymentBatch' => [
                                                                
                                ]
                ],
                'recurrence_size' => 0,
                'recurrence_unit' => '',
                'status' => '',
                'time_end' => '',
                'time_start' => ''
        ],
        'status' => ''
    ],
    'MasterCardAction' => [
        'alias' => [
                
        ],
        'all_mastercard_action_refund' => [
                [
                                'additional_information' => [
                                                                'attachment' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'id' => 0
                                                                                                                                ]
                                                                ],
                                                                'category' => '',
                                                                'comment' => '',
                                                                'reason' => '',
                                                                'terms_and_conditions' => ''
                                ],
                                'alias' => [
                                                                
                                ],
                                'amount' => [
                                                                
                                ],
                                'attachment' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'category' => '',
                                'comment' => '',
                                'counterparty_alias' => [
                                                                
                                ],
                                'created' => '',
                                'description' => '',
                                'id' => 0,
                                'label_card' => [
                                                                'expiry_date' => '',
                                                                'label_user' => [
                                                                                                                                
                                                                ],
                                                                'second_line' => '',
                                                                'status' => '',
                                                                'type' => '',
                                                                'uuid' => ''
                                ],
                                'label_user_creator' => [
                                                                
                                ],
                                'mastercard_action_id' => 0,
                                'reason' => '',
                                'reference_mastercard_action_event' => [
                                                                [
                                                                                                                                'event_id' => 0
                                                                ]
                                ],
                                'status' => '',
                                'status_description' => '',
                                'status_description_translated' => '',
                                'status_together_url' => '',
                                'sub_type' => '',
                                'terms_and_conditions' => '',
                                'time_refund' => '',
                                'type' => '',
                                'updated' => ''
                ]
        ],
        'amount_billing' => [
                
        ],
        'amount_converted' => [
                
        ],
        'amount_fee' => [
                
        ],
        'amount_local' => [
                
        ],
        'amount_original_billing' => [
                
        ],
        'amount_original_local' => [
                
        ],
        'applied_limit' => '',
        'authorisation_status' => '',
        'authorisation_type' => '',
        'card_authorisation_id_response' => '',
        'card_id' => 0,
        'city' => '',
        'clearing_expiry_time' => '',
        'clearing_status' => '',
        'counterparty_alias' => [
                
        ],
        'decision' => '',
        'decision_description' => '',
        'decision_description_translated' => '',
        'decision_together_url' => '',
        'description' => '',
        'eligible_whitelist_id' => 0,
        'id' => 0,
        'label_card' => [
                
        ],
        'maturity_date' => '',
        'monetary_account_id' => 0,
        'pan_entry_mode_user' => '',
        'payment_status' => '',
        'pos_card_holder_presence' => '',
        'pos_card_presence' => '',
        'request_reference_split_the_bill' => [
                [
                                
                ]
        ],
        'reservation_expiry_time' => '',
        'secure_code_id' => 0,
        'settlement_status' => '',
        'token_status' => '',
        'wallet_provider_id' => ''
    ],
    'Payment' => [
        
    ],
    'PaymentBatch' => [
        
    ],
    'RequestResponse' => [
        'address_billing' => [
                
        ],
        'address_shipping' => [
                
        ],
        'alias' => [
                
        ],
        'amount_inquired' => [
                
        ],
        'amount_responded' => [
                
        ],
        'attachment' => [
                [
                                'content_type' => '',
                                'description' => '',
                                'urls' => [
                                                                [
                                                                                                                                'type' => '',
                                                                                                                                'url' => ''
                                                                ]
                                ]
                ]
        ],
        'counterparty_alias' => [
                
        ],
        'created' => '',
        'credit_scheme_identifier' => '',
        'description' => '',
        'eligible_whitelist_id' => 0,
        'event_id' => 0,
        'geolocation' => [
                
        ],
        'id' => 0,
        'mandate_identifier' => '',
        'minimum_age' => 0,
        'monetary_account_id' => 0,
        'redirect_url' => '',
        'request_reference_split_the_bill' => [
                [
                                
                ]
        ],
        'require_address' => '',
        'status' => '',
        'sub_type' => '',
        'time_expiry' => '',
        'time_refund_requested' => '',
        'time_refunded' => '',
        'time_responded' => '',
        'type' => '',
        'updated' => '',
        'user_refund_requested' => [
                
        ]
    ],
    'ScheduleInstance' => [
        'error_message' => [
                
        ],
        'request_reference_split_the_bill' => [
                [
                                
                ]
        ],
        'result_object' => [
                'Payment' => [
                                
                ],
                'PaymentBatch' => [
                                
                ]
        ],
        'scheduled_object' => [
                
        ],
        'state' => '',
        'time_end' => '',
        'time_start' => ''
    ],
    'TransferwisePayment' => [
        'alias' => [
                
        ],
        'amount_source' => [
                
        ],
        'amount_target' => [
                
        ],
        'counterparty_alias' => [
                
        ],
        'monetary_account_id' => '',
        'pay_in_reference' => '',
        'quote' => [
                'amount_fee' => [
                                
                ],
                'amount_source' => [
                                
                ],
                'amount_target' => [
                                
                ],
                'created' => '',
                'currency_source' => '',
                'currency_target' => '',
                'id' => 0,
                'quote_id' => '',
                'rate' => '',
                'time_delivery_estimate' => '',
                'time_expiry' => '',
                'updated' => ''
        ],
        'rate' => '',
        'recipient_id' => '',
        'reference' => '',
        'status' => '',
        'status_transferwise' => '',
        'status_transferwise_issue' => '',
        'sub_status' => '',
        'time_delivery_estimate' => ''
    ],
    'WhitelistResult' => [
        'error_message' => [
                
        ],
        'id' => 0,
        'monetary_account_paying_id' => 0,
        'object' => [
                'draftPayment' => [
                                
                ],
                'id' => 0,
                'requestResponse' => [
                                
                ]
        ],
        'request_reference_split_the_bill' => [
                [
                                
                ]
        ],
        'status' => '',
        'sub_status' => '',
        'whitelist' => [
                
        ]
    ]
  ],
  'request_inquiries' => [
    [
        'address_billing' => [
                
        ],
        'address_shipping' => [
                
        ],
        'allow_amount_higher' => null,
        'allow_amount_lower' => null,
        'allow_bunqme' => null,
        'amount_inquired' => [
                
        ],
        'amount_responded' => [
                
        ],
        'attachment' => [
                [
                                'id' => 0
                ]
        ],
        'batch_id' => 0,
        'bunqme_share_url' => '',
        'counterparty_alias' => [
                
        ],
        'created' => '',
        'description' => '',
        'event_id' => 0,
        'geolocation' => [
                
        ],
        'id' => 0,
        'merchant_reference' => '',
        'minimum_age' => 0,
        'monetary_account_id' => 0,
        'redirect_url' => '',
        'reference_split_the_bill' => [
                
        ],
        'require_address' => '',
        'scheduled_id' => 0,
        'status' => '',
        'time_expiry' => '',
        'time_responded' => '',
        'updated' => '',
        'user_alias_created' => [
                
        ],
        'user_alias_revoked' => [
                
        ],
        'want_tip' => null
    ]
  ],
  'status' => '',
  'total_amount_inquired' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'event_id' => 0,
  'reference_split_the_bill' => [
    'BillingInvoice' => [
        'address' => [
                'city' => '',
                'country' => '',
                'extra' => '',
                'house_number' => '',
                'is_user_address_updated' => null,
                'mailbox_name' => '',
                'po_box' => '',
                'postal_code' => '',
                'province' => '',
                'street' => ''
        ],
        'alias' => [
                'avatar' => [
                                'anchor_uuid' => '',
                                'image' => [
                                                                [
                                                                                                                                'attachment_public_uuid' => '',
                                                                                                                                'content_type' => '',
                                                                                                                                'height' => 0,
                                                                                                                                'width' => 0
                                                                ]
                                ],
                                'style' => '',
                                'uuid' => ''
                ],
                'bunq_me' => [
                                'name' => '',
                                'service' => '',
                                'type' => '',
                                'value' => ''
                ],
                'country' => '',
                'display_name' => '',
                'iban' => '',
                'is_light' => null,
                'label_user' => [
                                'avatar' => [
                                                                
                                ],
                                'country' => '',
                                'display_name' => '',
                                'public_nick_name' => '',
                                'uuid' => ''
                ],
                'merchant_category_code' => '',
                'swift_account_number' => '',
                'swift_bic' => '',
                'transferwise_account_number' => '',
                'transferwise_bank_code' => ''
        ],
        'category' => '',
        'chamber_of_commerce_number' => '',
        'counterparty_address' => [
                
        ],
        'counterparty_alias' => [
                
        ],
        'created' => '',
        'description' => '',
        'external_url' => '',
        'group' => [
                [
                                'instance_description' => '',
                                'item' => [
                                                                [
                                                                                                                                'billing_date' => '',
                                                                                                                                'id' => 0,
                                                                                                                                'quantity' => 0,
                                                                                                                                'total_vat_exclusive' => [
                                                                                                                                                                                                                                                                'currency' => '',
                                                                                                                                                                                                                                                                'value' => ''
                                                                                                                                ],
                                                                                                                                'total_vat_inclusive' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'type_description' => '',
                                                                                                                                'type_description_translated' => '',
                                                                                                                                'unit_vat_exclusive' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'unit_vat_inclusive' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'vat' => 0
                                                                ]
                                ],
                                'product_vat_exclusive' => [
                                                                
                                ],
                                'product_vat_inclusive' => [
                                                                
                                ],
                                'type' => '',
                                'type_description' => '',
                                'type_description_translated' => ''
                ]
        ],
        'id' => 0,
        'invoice_date' => '',
        'invoice_number' => '',
        'request_reference_split_the_bill' => [
                [
                                'id' => 0,
                                'type' => ''
                ]
        ],
        'status' => '',
        'total_vat' => [
                
        ],
        'total_vat_exclusive' => [
                
        ],
        'total_vat_inclusive' => [
                
        ],
        'updated' => '',
        'vat_number' => ''
    ],
    'DraftPayment' => [
        'entries' => [
                [
                                'alias' => [
                                                                
                                ],
                                'amount' => [
                                                                
                                ],
                                'attachment' => [
                                                                [
                                                                                                                                'id' => 0,
                                                                                                                                'monetary_account_id' => 0
                                                                ]
                                ],
                                'counterparty_alias' => [
                                                                
                                ],
                                'description' => '',
                                'id' => 0,
                                'merchant_reference' => '',
                                'type' => ''
                ]
        ],
        'number_of_required_accepts' => 0,
        'previous_updated_timestamp' => '',
        'schedule' => [
                'object' => [
                                'Payment' => [
                                                                'address_billing' => [
                                                                                                                                
                                                                ],
                                                                'address_shipping' => [
                                                                                                                                
                                                                ],
                                                                'alias' => [
                                                                                                                                
                                                                ],
                                                                'allow_bunqto' => null,
                                                                'amount' => [
                                                                                                                                
                                                                ],
                                                                'attachment' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'balance_after_mutation' => [
                                                                                                                                
                                                                ],
                                                                'batch_id' => 0,
                                                                'bunqto_expiry' => '',
                                                                'bunqto_share_url' => '',
                                                                'bunqto_status' => '',
                                                                'bunqto_sub_status' => '',
                                                                'bunqto_time_responded' => '',
                                                                'counterparty_alias' => [
                                                                                                                                
                                                                ],
                                                                'created' => '',
                                                                'description' => '',
                                                                'geolocation' => [
                                                                                                                                'altitude' => 0,
                                                                                                                                'latitude' => 0,
                                                                                                                                'longitude' => 0,
                                                                                                                                'radius' => 0
                                                                ],
                                                                'id' => 0,
                                                                'merchant_reference' => '',
                                                                'monetary_account_id' => 0,
                                                                'payment_auto_allocate_instance' => [
                                                                                                                                'created' => '',
                                                                                                                                'error_message' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'id' => 0,
                                                                                                                                'payment_auto_allocate_id' => 0,
                                                                                                                                'payment_batch' => [
                                                                                                                                                                                                                                                                'payments' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'Payment' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'payment_id' => 0,
                                                                                                                                'status' => '',
                                                                                                                                'updated' => ''
                                                                ],
                                                                'request_reference_split_the_bill' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'scheduled_id' => 0,
                                                                'sub_type' => '',
                                                                'type' => '',
                                                                'updated' => ''
                                ],
                                'PaymentBatch' => [
                                                                
                                ]
                ],
                'recurrence_size' => 0,
                'recurrence_unit' => '',
                'status' => '',
                'time_end' => '',
                'time_start' => ''
        ],
        'status' => ''
    ],
    'MasterCardAction' => [
        'alias' => [
                
        ],
        'all_mastercard_action_refund' => [
                [
                                'additional_information' => [
                                                                'attachment' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'id' => 0
                                                                                                                                ]
                                                                ],
                                                                'category' => '',
                                                                'comment' => '',
                                                                'reason' => '',
                                                                'terms_and_conditions' => ''
                                ],
                                'alias' => [
                                                                
                                ],
                                'amount' => [
                                                                
                                ],
                                'attachment' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'category' => '',
                                'comment' => '',
                                'counterparty_alias' => [
                                                                
                                ],
                                'created' => '',
                                'description' => '',
                                'id' => 0,
                                'label_card' => [
                                                                'expiry_date' => '',
                                                                'label_user' => [
                                                                                                                                
                                                                ],
                                                                'second_line' => '',
                                                                'status' => '',
                                                                'type' => '',
                                                                'uuid' => ''
                                ],
                                'label_user_creator' => [
                                                                
                                ],
                                'mastercard_action_id' => 0,
                                'reason' => '',
                                'reference_mastercard_action_event' => [
                                                                [
                                                                                                                                'event_id' => 0
                                                                ]
                                ],
                                'status' => '',
                                'status_description' => '',
                                'status_description_translated' => '',
                                'status_together_url' => '',
                                'sub_type' => '',
                                'terms_and_conditions' => '',
                                'time_refund' => '',
                                'type' => '',
                                'updated' => ''
                ]
        ],
        'amount_billing' => [
                
        ],
        'amount_converted' => [
                
        ],
        'amount_fee' => [
                
        ],
        'amount_local' => [
                
        ],
        'amount_original_billing' => [
                
        ],
        'amount_original_local' => [
                
        ],
        'applied_limit' => '',
        'authorisation_status' => '',
        'authorisation_type' => '',
        'card_authorisation_id_response' => '',
        'card_id' => 0,
        'city' => '',
        'clearing_expiry_time' => '',
        'clearing_status' => '',
        'counterparty_alias' => [
                
        ],
        'decision' => '',
        'decision_description' => '',
        'decision_description_translated' => '',
        'decision_together_url' => '',
        'description' => '',
        'eligible_whitelist_id' => 0,
        'id' => 0,
        'label_card' => [
                
        ],
        'maturity_date' => '',
        'monetary_account_id' => 0,
        'pan_entry_mode_user' => '',
        'payment_status' => '',
        'pos_card_holder_presence' => '',
        'pos_card_presence' => '',
        'request_reference_split_the_bill' => [
                [
                                
                ]
        ],
        'reservation_expiry_time' => '',
        'secure_code_id' => 0,
        'settlement_status' => '',
        'token_status' => '',
        'wallet_provider_id' => ''
    ],
    'Payment' => [
        
    ],
    'PaymentBatch' => [
        
    ],
    'RequestResponse' => [
        'address_billing' => [
                
        ],
        'address_shipping' => [
                
        ],
        'alias' => [
                
        ],
        'amount_inquired' => [
                
        ],
        'amount_responded' => [
                
        ],
        'attachment' => [
                [
                                'content_type' => '',
                                'description' => '',
                                'urls' => [
                                                                [
                                                                                                                                'type' => '',
                                                                                                                                'url' => ''
                                                                ]
                                ]
                ]
        ],
        'counterparty_alias' => [
                
        ],
        'created' => '',
        'credit_scheme_identifier' => '',
        'description' => '',
        'eligible_whitelist_id' => 0,
        'event_id' => 0,
        'geolocation' => [
                
        ],
        'id' => 0,
        'mandate_identifier' => '',
        'minimum_age' => 0,
        'monetary_account_id' => 0,
        'redirect_url' => '',
        'request_reference_split_the_bill' => [
                [
                                
                ]
        ],
        'require_address' => '',
        'status' => '',
        'sub_type' => '',
        'time_expiry' => '',
        'time_refund_requested' => '',
        'time_refunded' => '',
        'time_responded' => '',
        'type' => '',
        'updated' => '',
        'user_refund_requested' => [
                
        ]
    ],
    'ScheduleInstance' => [
        'error_message' => [
                
        ],
        'request_reference_split_the_bill' => [
                [
                                
                ]
        ],
        'result_object' => [
                'Payment' => [
                                
                ],
                'PaymentBatch' => [
                                
                ]
        ],
        'scheduled_object' => [
                
        ],
        'state' => '',
        'time_end' => '',
        'time_start' => ''
    ],
    'TransferwisePayment' => [
        'alias' => [
                
        ],
        'amount_source' => [
                
        ],
        'amount_target' => [
                
        ],
        'counterparty_alias' => [
                
        ],
        'monetary_account_id' => '',
        'pay_in_reference' => '',
        'quote' => [
                'amount_fee' => [
                                
                ],
                'amount_source' => [
                                
                ],
                'amount_target' => [
                                
                ],
                'created' => '',
                'currency_source' => '',
                'currency_target' => '',
                'id' => 0,
                'quote_id' => '',
                'rate' => '',
                'time_delivery_estimate' => '',
                'time_expiry' => '',
                'updated' => ''
        ],
        'rate' => '',
        'recipient_id' => '',
        'reference' => '',
        'status' => '',
        'status_transferwise' => '',
        'status_transferwise_issue' => '',
        'sub_status' => '',
        'time_delivery_estimate' => ''
    ],
    'WhitelistResult' => [
        'error_message' => [
                
        ],
        'id' => 0,
        'monetary_account_paying_id' => 0,
        'object' => [
                'draftPayment' => [
                                
                ],
                'id' => 0,
                'requestResponse' => [
                                
                ]
        ],
        'request_reference_split_the_bill' => [
                [
                                
                ]
        ],
        'status' => '',
        'sub_status' => '',
        'whitelist' => [
                
        ]
    ]
  ],
  'request_inquiries' => [
    [
        'address_billing' => [
                
        ],
        'address_shipping' => [
                
        ],
        'allow_amount_higher' => null,
        'allow_amount_lower' => null,
        'allow_bunqme' => null,
        'amount_inquired' => [
                
        ],
        'amount_responded' => [
                
        ],
        'attachment' => [
                [
                                'id' => 0
                ]
        ],
        'batch_id' => 0,
        'bunqme_share_url' => '',
        'counterparty_alias' => [
                
        ],
        'created' => '',
        'description' => '',
        'event_id' => 0,
        'geolocation' => [
                
        ],
        'id' => 0,
        'merchant_reference' => '',
        'minimum_age' => 0,
        'monetary_account_id' => 0,
        'redirect_url' => '',
        'reference_split_the_bill' => [
                
        ],
        'require_address' => '',
        'scheduled_id' => 0,
        'status' => '',
        'time_expiry' => '',
        'time_responded' => '',
        'updated' => '',
        'user_alias_created' => [
                
        ],
        'user_alias_revoked' => [
                
        ],
        'want_tip' => null
    ]
  ],
  'status' => '',
  'total_amount_inquired' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "event_id": 0,
  "reference_split_the_bill": {
    "BillingInvoice": {
      "address": {
        "city": "",
        "country": "",
        "extra": "",
        "house_number": "",
        "is_user_address_updated": false,
        "mailbox_name": "",
        "po_box": "",
        "postal_code": "",
        "province": "",
        "street": ""
      },
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "category": "",
      "chamber_of_commerce_number": "",
      "counterparty_address": {},
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "external_url": "",
      "group": [
        {
          "instance_description": "",
          "item": [
            {
              "billing_date": "",
              "id": 0,
              "quantity": 0,
              "total_vat_exclusive": {
                "currency": "",
                "value": ""
              },
              "total_vat_inclusive": {},
              "type_description": "",
              "type_description_translated": "",
              "unit_vat_exclusive": {},
              "unit_vat_inclusive": {},
              "vat": 0
            }
          ],
          "product_vat_exclusive": {},
          "product_vat_inclusive": {},
          "type": "",
          "type_description": "",
          "type_description_translated": ""
        }
      ],
      "id": 0,
      "invoice_date": "",
      "invoice_number": "",
      "request_reference_split_the_bill": [
        {
          "id": 0,
          "type": ""
        }
      ],
      "status": "",
      "total_vat": {},
      "total_vat_exclusive": {},
      "total_vat_inclusive": {},
      "updated": "",
      "vat_number": ""
    },
    "DraftPayment": {
      "entries": [
        {
          "alias": {},
          "amount": {},
          "attachment": [
            {
              "id": 0,
              "monetary_account_id": 0
            }
          ],
          "counterparty_alias": {},
          "description": "",
          "id": 0,
          "merchant_reference": "",
          "type": ""
        }
      ],
      "number_of_required_accepts": 0,
      "previous_updated_timestamp": "",
      "schedule": {
        "object": {
          "Payment": {
            "address_billing": {},
            "address_shipping": {},
            "alias": {},
            "allow_bunqto": false,
            "amount": {},
            "attachment": [
              {}
            ],
            "balance_after_mutation": {},
            "batch_id": 0,
            "bunqto_expiry": "",
            "bunqto_share_url": "",
            "bunqto_status": "",
            "bunqto_sub_status": "",
            "bunqto_time_responded": "",
            "counterparty_alias": {},
            "created": "",
            "description": "",
            "geolocation": {
              "altitude": 0,
              "latitude": 0,
              "longitude": 0,
              "radius": 0
            },
            "id": 0,
            "merchant_reference": "",
            "monetary_account_id": 0,
            "payment_auto_allocate_instance": {
              "created": "",
              "error_message": [],
              "id": 0,
              "payment_auto_allocate_id": 0,
              "payment_batch": {
                "payments": {
                  "Payment": []
                }
              },
              "payment_id": 0,
              "status": "",
              "updated": ""
            },
            "request_reference_split_the_bill": [
              {}
            ],
            "scheduled_id": 0,
            "sub_type": "",
            "type": "",
            "updated": ""
          },
          "PaymentBatch": {}
        },
        "recurrence_size": 0,
        "recurrence_unit": "",
        "status": "",
        "time_end": "",
        "time_start": ""
      },
      "status": ""
    },
    "MasterCardAction": {
      "alias": {},
      "all_mastercard_action_refund": [
        {
          "additional_information": {
            "attachment": [
              {
                "id": 0
              }
            ],
            "category": "",
            "comment": "",
            "reason": "",
            "terms_and_conditions": ""
          },
          "alias": {},
          "amount": {},
          "attachment": [
            {}
          ],
          "category": "",
          "comment": "",
          "counterparty_alias": {},
          "created": "",
          "description": "",
          "id": 0,
          "label_card": {
            "expiry_date": "",
            "label_user": {},
            "second_line": "",
            "status": "",
            "type": "",
            "uuid": ""
          },
          "label_user_creator": {},
          "mastercard_action_id": 0,
          "reason": "",
          "reference_mastercard_action_event": [
            {
              "event_id": 0
            }
          ],
          "status": "",
          "status_description": "",
          "status_description_translated": "",
          "status_together_url": "",
          "sub_type": "",
          "terms_and_conditions": "",
          "time_refund": "",
          "type": "",
          "updated": ""
        }
      ],
      "amount_billing": {},
      "amount_converted": {},
      "amount_fee": {},
      "amount_local": {},
      "amount_original_billing": {},
      "amount_original_local": {},
      "applied_limit": "",
      "authorisation_status": "",
      "authorisation_type": "",
      "card_authorisation_id_response": "",
      "card_id": 0,
      "city": "",
      "clearing_expiry_time": "",
      "clearing_status": "",
      "counterparty_alias": {},
      "decision": "",
      "decision_description": "",
      "decision_description_translated": "",
      "decision_together_url": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "id": 0,
      "label_card": {},
      "maturity_date": "",
      "monetary_account_id": 0,
      "pan_entry_mode_user": "",
      "payment_status": "",
      "pos_card_holder_presence": "",
      "pos_card_presence": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "reservation_expiry_time": "",
      "secure_code_id": 0,
      "settlement_status": "",
      "token_status": "",
      "wallet_provider_id": ""
    },
    "Payment": {},
    "PaymentBatch": {},
    "RequestResponse": {
      "address_billing": {},
      "address_shipping": {},
      "alias": {},
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "content_type": "",
          "description": "",
          "urls": [
            {
              "type": "",
              "url": ""
            }
          ]
        }
      ],
      "counterparty_alias": {},
      "created": "",
      "credit_scheme_identifier": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "mandate_identifier": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "require_address": "",
      "status": "",
      "sub_type": "",
      "time_expiry": "",
      "time_refund_requested": "",
      "time_refunded": "",
      "time_responded": "",
      "type": "",
      "updated": "",
      "user_refund_requested": {}
    },
    "ScheduleInstance": {
      "error_message": [],
      "request_reference_split_the_bill": [
        {}
      ],
      "result_object": {
        "Payment": {},
        "PaymentBatch": {}
      },
      "scheduled_object": {},
      "state": "",
      "time_end": "",
      "time_start": ""
    },
    "TransferwisePayment": {
      "alias": {},
      "amount_source": {},
      "amount_target": {},
      "counterparty_alias": {},
      "monetary_account_id": "",
      "pay_in_reference": "",
      "quote": {
        "amount_fee": {},
        "amount_source": {},
        "amount_target": {},
        "created": "",
        "currency_source": "",
        "currency_target": "",
        "id": 0,
        "quote_id": "",
        "rate": "",
        "time_delivery_estimate": "",
        "time_expiry": "",
        "updated": ""
      },
      "rate": "",
      "recipient_id": "",
      "reference": "",
      "status": "",
      "status_transferwise": "",
      "status_transferwise_issue": "",
      "sub_status": "",
      "time_delivery_estimate": ""
    },
    "WhitelistResult": {
      "error_message": [],
      "id": 0,
      "monetary_account_paying_id": 0,
      "object": {
        "draftPayment": {},
        "id": 0,
        "requestResponse": {}
      },
      "request_reference_split_the_bill": [
        {}
      ],
      "status": "",
      "sub_status": "",
      "whitelist": {}
    }
  },
  "request_inquiries": [
    {
      "address_billing": {},
      "address_shipping": {},
      "allow_amount_higher": false,
      "allow_amount_lower": false,
      "allow_bunqme": false,
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "id": 0
        }
      ],
      "batch_id": 0,
      "bunqme_share_url": "",
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "merchant_reference": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "reference_split_the_bill": {},
      "require_address": "",
      "scheduled_id": 0,
      "status": "",
      "time_expiry": "",
      "time_responded": "",
      "updated": "",
      "user_alias_created": {},
      "user_alias_revoked": {},
      "want_tip": false
    }
  ],
  "status": "",
  "total_amount_inquired": {}
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "event_id": 0,
  "reference_split_the_bill": {
    "BillingInvoice": {
      "address": {
        "city": "",
        "country": "",
        "extra": "",
        "house_number": "",
        "is_user_address_updated": false,
        "mailbox_name": "",
        "po_box": "",
        "postal_code": "",
        "province": "",
        "street": ""
      },
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "category": "",
      "chamber_of_commerce_number": "",
      "counterparty_address": {},
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "external_url": "",
      "group": [
        {
          "instance_description": "",
          "item": [
            {
              "billing_date": "",
              "id": 0,
              "quantity": 0,
              "total_vat_exclusive": {
                "currency": "",
                "value": ""
              },
              "total_vat_inclusive": {},
              "type_description": "",
              "type_description_translated": "",
              "unit_vat_exclusive": {},
              "unit_vat_inclusive": {},
              "vat": 0
            }
          ],
          "product_vat_exclusive": {},
          "product_vat_inclusive": {},
          "type": "",
          "type_description": "",
          "type_description_translated": ""
        }
      ],
      "id": 0,
      "invoice_date": "",
      "invoice_number": "",
      "request_reference_split_the_bill": [
        {
          "id": 0,
          "type": ""
        }
      ],
      "status": "",
      "total_vat": {},
      "total_vat_exclusive": {},
      "total_vat_inclusive": {},
      "updated": "",
      "vat_number": ""
    },
    "DraftPayment": {
      "entries": [
        {
          "alias": {},
          "amount": {},
          "attachment": [
            {
              "id": 0,
              "monetary_account_id": 0
            }
          ],
          "counterparty_alias": {},
          "description": "",
          "id": 0,
          "merchant_reference": "",
          "type": ""
        }
      ],
      "number_of_required_accepts": 0,
      "previous_updated_timestamp": "",
      "schedule": {
        "object": {
          "Payment": {
            "address_billing": {},
            "address_shipping": {},
            "alias": {},
            "allow_bunqto": false,
            "amount": {},
            "attachment": [
              {}
            ],
            "balance_after_mutation": {},
            "batch_id": 0,
            "bunqto_expiry": "",
            "bunqto_share_url": "",
            "bunqto_status": "",
            "bunqto_sub_status": "",
            "bunqto_time_responded": "",
            "counterparty_alias": {},
            "created": "",
            "description": "",
            "geolocation": {
              "altitude": 0,
              "latitude": 0,
              "longitude": 0,
              "radius": 0
            },
            "id": 0,
            "merchant_reference": "",
            "monetary_account_id": 0,
            "payment_auto_allocate_instance": {
              "created": "",
              "error_message": [],
              "id": 0,
              "payment_auto_allocate_id": 0,
              "payment_batch": {
                "payments": {
                  "Payment": []
                }
              },
              "payment_id": 0,
              "status": "",
              "updated": ""
            },
            "request_reference_split_the_bill": [
              {}
            ],
            "scheduled_id": 0,
            "sub_type": "",
            "type": "",
            "updated": ""
          },
          "PaymentBatch": {}
        },
        "recurrence_size": 0,
        "recurrence_unit": "",
        "status": "",
        "time_end": "",
        "time_start": ""
      },
      "status": ""
    },
    "MasterCardAction": {
      "alias": {},
      "all_mastercard_action_refund": [
        {
          "additional_information": {
            "attachment": [
              {
                "id": 0
              }
            ],
            "category": "",
            "comment": "",
            "reason": "",
            "terms_and_conditions": ""
          },
          "alias": {},
          "amount": {},
          "attachment": [
            {}
          ],
          "category": "",
          "comment": "",
          "counterparty_alias": {},
          "created": "",
          "description": "",
          "id": 0,
          "label_card": {
            "expiry_date": "",
            "label_user": {},
            "second_line": "",
            "status": "",
            "type": "",
            "uuid": ""
          },
          "label_user_creator": {},
          "mastercard_action_id": 0,
          "reason": "",
          "reference_mastercard_action_event": [
            {
              "event_id": 0
            }
          ],
          "status": "",
          "status_description": "",
          "status_description_translated": "",
          "status_together_url": "",
          "sub_type": "",
          "terms_and_conditions": "",
          "time_refund": "",
          "type": "",
          "updated": ""
        }
      ],
      "amount_billing": {},
      "amount_converted": {},
      "amount_fee": {},
      "amount_local": {},
      "amount_original_billing": {},
      "amount_original_local": {},
      "applied_limit": "",
      "authorisation_status": "",
      "authorisation_type": "",
      "card_authorisation_id_response": "",
      "card_id": 0,
      "city": "",
      "clearing_expiry_time": "",
      "clearing_status": "",
      "counterparty_alias": {},
      "decision": "",
      "decision_description": "",
      "decision_description_translated": "",
      "decision_together_url": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "id": 0,
      "label_card": {},
      "maturity_date": "",
      "monetary_account_id": 0,
      "pan_entry_mode_user": "",
      "payment_status": "",
      "pos_card_holder_presence": "",
      "pos_card_presence": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "reservation_expiry_time": "",
      "secure_code_id": 0,
      "settlement_status": "",
      "token_status": "",
      "wallet_provider_id": ""
    },
    "Payment": {},
    "PaymentBatch": {},
    "RequestResponse": {
      "address_billing": {},
      "address_shipping": {},
      "alias": {},
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "content_type": "",
          "description": "",
          "urls": [
            {
              "type": "",
              "url": ""
            }
          ]
        }
      ],
      "counterparty_alias": {},
      "created": "",
      "credit_scheme_identifier": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "mandate_identifier": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "require_address": "",
      "status": "",
      "sub_type": "",
      "time_expiry": "",
      "time_refund_requested": "",
      "time_refunded": "",
      "time_responded": "",
      "type": "",
      "updated": "",
      "user_refund_requested": {}
    },
    "ScheduleInstance": {
      "error_message": [],
      "request_reference_split_the_bill": [
        {}
      ],
      "result_object": {
        "Payment": {},
        "PaymentBatch": {}
      },
      "scheduled_object": {},
      "state": "",
      "time_end": "",
      "time_start": ""
    },
    "TransferwisePayment": {
      "alias": {},
      "amount_source": {},
      "amount_target": {},
      "counterparty_alias": {},
      "monetary_account_id": "",
      "pay_in_reference": "",
      "quote": {
        "amount_fee": {},
        "amount_source": {},
        "amount_target": {},
        "created": "",
        "currency_source": "",
        "currency_target": "",
        "id": 0,
        "quote_id": "",
        "rate": "",
        "time_delivery_estimate": "",
        "time_expiry": "",
        "updated": ""
      },
      "rate": "",
      "recipient_id": "",
      "reference": "",
      "status": "",
      "status_transferwise": "",
      "status_transferwise_issue": "",
      "sub_status": "",
      "time_delivery_estimate": ""
    },
    "WhitelistResult": {
      "error_message": [],
      "id": 0,
      "monetary_account_paying_id": 0,
      "object": {
        "draftPayment": {},
        "id": 0,
        "requestResponse": {}
      },
      "request_reference_split_the_bill": [
        {}
      ],
      "status": "",
      "sub_status": "",
      "whitelist": {}
    }
  },
  "request_inquiries": [
    {
      "address_billing": {},
      "address_shipping": {},
      "allow_amount_higher": false,
      "allow_amount_lower": false,
      "allow_bunqme": false,
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "id": 0
        }
      ],
      "batch_id": 0,
      "bunqme_share_url": "",
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "merchant_reference": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "reference_split_the_bill": {},
      "require_address": "",
      "scheduled_id": 0,
      "status": "",
      "time_expiry": "",
      "time_responded": "",
      "updated": "",
      "user_alias_created": {},
      "user_alias_revoked": {},
      "want_tip": false
    }
  ],
  "status": "",
  "total_amount_inquired": {}
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"event_id\": 0,\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {\n                \"currency\": \"\",\n                \"value\": \"\"\n              },\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {\n              \"altitude\": 0,\n              \"latitude\": 0,\n              \"longitude\": 0,\n              \"radius\": 0\n            },\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"request_inquiries\": [\n    {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"allow_amount_higher\": false,\n      \"allow_amount_lower\": false,\n      \"allow_bunqme\": false,\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"id\": 0\n        }\n      ],\n      \"batch_id\": 0,\n      \"bunqme_share_url\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"reference_split_the_bill\": {},\n      \"require_address\": \"\",\n      \"scheduled_id\": 0,\n      \"status\": \"\",\n      \"time_expiry\": \"\",\n      \"time_responded\": \"\",\n      \"updated\": \"\",\n      \"user_alias_created\": {},\n      \"user_alias_revoked\": {},\n      \"want_tip\": false\n    }\n  ],\n  \"status\": \"\",\n  \"total_amount_inquired\": {}\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch"

payload = {
    "event_id": 0,
    "reference_split_the_bill": {
        "BillingInvoice": {
            "address": {
                "city": "",
                "country": "",
                "extra": "",
                "house_number": "",
                "is_user_address_updated": False,
                "mailbox_name": "",
                "po_box": "",
                "postal_code": "",
                "province": "",
                "street": ""
            },
            "alias": {
                "avatar": {
                    "anchor_uuid": "",
                    "image": [
                        {
                            "attachment_public_uuid": "",
                            "content_type": "",
                            "height": 0,
                            "width": 0
                        }
                    ],
                    "style": "",
                    "uuid": ""
                },
                "bunq_me": {
                    "name": "",
                    "service": "",
                    "type": "",
                    "value": ""
                },
                "country": "",
                "display_name": "",
                "iban": "",
                "is_light": False,
                "label_user": {
                    "avatar": {},
                    "country": "",
                    "display_name": "",
                    "public_nick_name": "",
                    "uuid": ""
                },
                "merchant_category_code": "",
                "swift_account_number": "",
                "swift_bic": "",
                "transferwise_account_number": "",
                "transferwise_bank_code": ""
            },
            "category": "",
            "chamber_of_commerce_number": "",
            "counterparty_address": {},
            "counterparty_alias": {},
            "created": "",
            "description": "",
            "external_url": "",
            "group": [
                {
                    "instance_description": "",
                    "item": [
                        {
                            "billing_date": "",
                            "id": 0,
                            "quantity": 0,
                            "total_vat_exclusive": {
                                "currency": "",
                                "value": ""
                            },
                            "total_vat_inclusive": {},
                            "type_description": "",
                            "type_description_translated": "",
                            "unit_vat_exclusive": {},
                            "unit_vat_inclusive": {},
                            "vat": 0
                        }
                    ],
                    "product_vat_exclusive": {},
                    "product_vat_inclusive": {},
                    "type": "",
                    "type_description": "",
                    "type_description_translated": ""
                }
            ],
            "id": 0,
            "invoice_date": "",
            "invoice_number": "",
            "request_reference_split_the_bill": [
                {
                    "id": 0,
                    "type": ""
                }
            ],
            "status": "",
            "total_vat": {},
            "total_vat_exclusive": {},
            "total_vat_inclusive": {},
            "updated": "",
            "vat_number": ""
        },
        "DraftPayment": {
            "entries": [
                {
                    "alias": {},
                    "amount": {},
                    "attachment": [
                        {
                            "id": 0,
                            "monetary_account_id": 0
                        }
                    ],
                    "counterparty_alias": {},
                    "description": "",
                    "id": 0,
                    "merchant_reference": "",
                    "type": ""
                }
            ],
            "number_of_required_accepts": 0,
            "previous_updated_timestamp": "",
            "schedule": {
                "object": {
                    "Payment": {
                        "address_billing": {},
                        "address_shipping": {},
                        "alias": {},
                        "allow_bunqto": False,
                        "amount": {},
                        "attachment": [{}],
                        "balance_after_mutation": {},
                        "batch_id": 0,
                        "bunqto_expiry": "",
                        "bunqto_share_url": "",
                        "bunqto_status": "",
                        "bunqto_sub_status": "",
                        "bunqto_time_responded": "",
                        "counterparty_alias": {},
                        "created": "",
                        "description": "",
                        "geolocation": {
                            "altitude": 0,
                            "latitude": 0,
                            "longitude": 0,
                            "radius": 0
                        },
                        "id": 0,
                        "merchant_reference": "",
                        "monetary_account_id": 0,
                        "payment_auto_allocate_instance": {
                            "created": "",
                            "error_message": [],
                            "id": 0,
                            "payment_auto_allocate_id": 0,
                            "payment_batch": { "payments": { "Payment": [] } },
                            "payment_id": 0,
                            "status": "",
                            "updated": ""
                        },
                        "request_reference_split_the_bill": [{}],
                        "scheduled_id": 0,
                        "sub_type": "",
                        "type": "",
                        "updated": ""
                    },
                    "PaymentBatch": {}
                },
                "recurrence_size": 0,
                "recurrence_unit": "",
                "status": "",
                "time_end": "",
                "time_start": ""
            },
            "status": ""
        },
        "MasterCardAction": {
            "alias": {},
            "all_mastercard_action_refund": [
                {
                    "additional_information": {
                        "attachment": [{ "id": 0 }],
                        "category": "",
                        "comment": "",
                        "reason": "",
                        "terms_and_conditions": ""
                    },
                    "alias": {},
                    "amount": {},
                    "attachment": [{}],
                    "category": "",
                    "comment": "",
                    "counterparty_alias": {},
                    "created": "",
                    "description": "",
                    "id": 0,
                    "label_card": {
                        "expiry_date": "",
                        "label_user": {},
                        "second_line": "",
                        "status": "",
                        "type": "",
                        "uuid": ""
                    },
                    "label_user_creator": {},
                    "mastercard_action_id": 0,
                    "reason": "",
                    "reference_mastercard_action_event": [{ "event_id": 0 }],
                    "status": "",
                    "status_description": "",
                    "status_description_translated": "",
                    "status_together_url": "",
                    "sub_type": "",
                    "terms_and_conditions": "",
                    "time_refund": "",
                    "type": "",
                    "updated": ""
                }
            ],
            "amount_billing": {},
            "amount_converted": {},
            "amount_fee": {},
            "amount_local": {},
            "amount_original_billing": {},
            "amount_original_local": {},
            "applied_limit": "",
            "authorisation_status": "",
            "authorisation_type": "",
            "card_authorisation_id_response": "",
            "card_id": 0,
            "city": "",
            "clearing_expiry_time": "",
            "clearing_status": "",
            "counterparty_alias": {},
            "decision": "",
            "decision_description": "",
            "decision_description_translated": "",
            "decision_together_url": "",
            "description": "",
            "eligible_whitelist_id": 0,
            "id": 0,
            "label_card": {},
            "maturity_date": "",
            "monetary_account_id": 0,
            "pan_entry_mode_user": "",
            "payment_status": "",
            "pos_card_holder_presence": "",
            "pos_card_presence": "",
            "request_reference_split_the_bill": [{}],
            "reservation_expiry_time": "",
            "secure_code_id": 0,
            "settlement_status": "",
            "token_status": "",
            "wallet_provider_id": ""
        },
        "Payment": {},
        "PaymentBatch": {},
        "RequestResponse": {
            "address_billing": {},
            "address_shipping": {},
            "alias": {},
            "amount_inquired": {},
            "amount_responded": {},
            "attachment": [
                {
                    "content_type": "",
                    "description": "",
                    "urls": [
                        {
                            "type": "",
                            "url": ""
                        }
                    ]
                }
            ],
            "counterparty_alias": {},
            "created": "",
            "credit_scheme_identifier": "",
            "description": "",
            "eligible_whitelist_id": 0,
            "event_id": 0,
            "geolocation": {},
            "id": 0,
            "mandate_identifier": "",
            "minimum_age": 0,
            "monetary_account_id": 0,
            "redirect_url": "",
            "request_reference_split_the_bill": [{}],
            "require_address": "",
            "status": "",
            "sub_type": "",
            "time_expiry": "",
            "time_refund_requested": "",
            "time_refunded": "",
            "time_responded": "",
            "type": "",
            "updated": "",
            "user_refund_requested": {}
        },
        "ScheduleInstance": {
            "error_message": [],
            "request_reference_split_the_bill": [{}],
            "result_object": {
                "Payment": {},
                "PaymentBatch": {}
            },
            "scheduled_object": {},
            "state": "",
            "time_end": "",
            "time_start": ""
        },
        "TransferwisePayment": {
            "alias": {},
            "amount_source": {},
            "amount_target": {},
            "counterparty_alias": {},
            "monetary_account_id": "",
            "pay_in_reference": "",
            "quote": {
                "amount_fee": {},
                "amount_source": {},
                "amount_target": {},
                "created": "",
                "currency_source": "",
                "currency_target": "",
                "id": 0,
                "quote_id": "",
                "rate": "",
                "time_delivery_estimate": "",
                "time_expiry": "",
                "updated": ""
            },
            "rate": "",
            "recipient_id": "",
            "reference": "",
            "status": "",
            "status_transferwise": "",
            "status_transferwise_issue": "",
            "sub_status": "",
            "time_delivery_estimate": ""
        },
        "WhitelistResult": {
            "error_message": [],
            "id": 0,
            "monetary_account_paying_id": 0,
            "object": {
                "draftPayment": {},
                "id": 0,
                "requestResponse": {}
            },
            "request_reference_split_the_bill": [{}],
            "status": "",
            "sub_status": "",
            "whitelist": {}
        }
    },
    "request_inquiries": [
        {
            "address_billing": {},
            "address_shipping": {},
            "allow_amount_higher": False,
            "allow_amount_lower": False,
            "allow_bunqme": False,
            "amount_inquired": {},
            "amount_responded": {},
            "attachment": [{ "id": 0 }],
            "batch_id": 0,
            "bunqme_share_url": "",
            "counterparty_alias": {},
            "created": "",
            "description": "",
            "event_id": 0,
            "geolocation": {},
            "id": 0,
            "merchant_reference": "",
            "minimum_age": 0,
            "monetary_account_id": 0,
            "redirect_url": "",
            "reference_split_the_bill": {},
            "require_address": "",
            "scheduled_id": 0,
            "status": "",
            "time_expiry": "",
            "time_responded": "",
            "updated": "",
            "user_alias_created": {},
            "user_alias_revoked": {},
            "want_tip": False
        }
    ],
    "status": "",
    "total_amount_inquired": {}
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch"

payload <- "{\n  \"event_id\": 0,\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {\n                \"currency\": \"\",\n                \"value\": \"\"\n              },\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {\n              \"altitude\": 0,\n              \"latitude\": 0,\n              \"longitude\": 0,\n              \"radius\": 0\n            },\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"request_inquiries\": [\n    {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"allow_amount_higher\": false,\n      \"allow_amount_lower\": false,\n      \"allow_bunqme\": false,\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"id\": 0\n        }\n      ],\n      \"batch_id\": 0,\n      \"bunqme_share_url\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"reference_split_the_bill\": {},\n      \"require_address\": \"\",\n      \"scheduled_id\": 0,\n      \"status\": \"\",\n      \"time_expiry\": \"\",\n      \"time_responded\": \"\",\n      \"updated\": \"\",\n      \"user_alias_created\": {},\n      \"user_alias_revoked\": {},\n      \"want_tip\": false\n    }\n  ],\n  \"status\": \"\",\n  \"total_amount_inquired\": {}\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"event_id\": 0,\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {\n                \"currency\": \"\",\n                \"value\": \"\"\n              },\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {\n              \"altitude\": 0,\n              \"latitude\": 0,\n              \"longitude\": 0,\n              \"radius\": 0\n            },\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"request_inquiries\": [\n    {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"allow_amount_higher\": false,\n      \"allow_amount_lower\": false,\n      \"allow_bunqme\": false,\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"id\": 0\n        }\n      ],\n      \"batch_id\": 0,\n      \"bunqme_share_url\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"reference_split_the_bill\": {},\n      \"require_address\": \"\",\n      \"scheduled_id\": 0,\n      \"status\": \"\",\n      \"time_expiry\": \"\",\n      \"time_responded\": \"\",\n      \"updated\": \"\",\n      \"user_alias_created\": {},\n      \"user_alias_revoked\": {},\n      \"want_tip\": false\n    }\n  ],\n  \"status\": \"\",\n  \"total_amount_inquired\": {}\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"event_id\": 0,\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {\n                \"currency\": \"\",\n                \"value\": \"\"\n              },\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {\n              \"altitude\": 0,\n              \"latitude\": 0,\n              \"longitude\": 0,\n              \"radius\": 0\n            },\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"request_inquiries\": [\n    {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"allow_amount_higher\": false,\n      \"allow_amount_lower\": false,\n      \"allow_bunqme\": false,\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"id\": 0\n        }\n      ],\n      \"batch_id\": 0,\n      \"bunqme_share_url\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"reference_split_the_bill\": {},\n      \"require_address\": \"\",\n      \"scheduled_id\": 0,\n      \"status\": \"\",\n      \"time_expiry\": \"\",\n      \"time_responded\": \"\",\n      \"updated\": \"\",\n      \"user_alias_created\": {},\n      \"user_alias_revoked\": {},\n      \"want_tip\": false\n    }\n  ],\n  \"status\": \"\",\n  \"total_amount_inquired\": {}\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch";

    let payload = json!({
        "event_id": 0,
        "reference_split_the_bill": json!({
            "BillingInvoice": json!({
                "address": json!({
                    "city": "",
                    "country": "",
                    "extra": "",
                    "house_number": "",
                    "is_user_address_updated": false,
                    "mailbox_name": "",
                    "po_box": "",
                    "postal_code": "",
                    "province": "",
                    "street": ""
                }),
                "alias": json!({
                    "avatar": json!({
                        "anchor_uuid": "",
                        "image": (
                            json!({
                                "attachment_public_uuid": "",
                                "content_type": "",
                                "height": 0,
                                "width": 0
                            })
                        ),
                        "style": "",
                        "uuid": ""
                    }),
                    "bunq_me": json!({
                        "name": "",
                        "service": "",
                        "type": "",
                        "value": ""
                    }),
                    "country": "",
                    "display_name": "",
                    "iban": "",
                    "is_light": false,
                    "label_user": json!({
                        "avatar": json!({}),
                        "country": "",
                        "display_name": "",
                        "public_nick_name": "",
                        "uuid": ""
                    }),
                    "merchant_category_code": "",
                    "swift_account_number": "",
                    "swift_bic": "",
                    "transferwise_account_number": "",
                    "transferwise_bank_code": ""
                }),
                "category": "",
                "chamber_of_commerce_number": "",
                "counterparty_address": json!({}),
                "counterparty_alias": json!({}),
                "created": "",
                "description": "",
                "external_url": "",
                "group": (
                    json!({
                        "instance_description": "",
                        "item": (
                            json!({
                                "billing_date": "",
                                "id": 0,
                                "quantity": 0,
                                "total_vat_exclusive": json!({
                                    "currency": "",
                                    "value": ""
                                }),
                                "total_vat_inclusive": json!({}),
                                "type_description": "",
                                "type_description_translated": "",
                                "unit_vat_exclusive": json!({}),
                                "unit_vat_inclusive": json!({}),
                                "vat": 0
                            })
                        ),
                        "product_vat_exclusive": json!({}),
                        "product_vat_inclusive": json!({}),
                        "type": "",
                        "type_description": "",
                        "type_description_translated": ""
                    })
                ),
                "id": 0,
                "invoice_date": "",
                "invoice_number": "",
                "request_reference_split_the_bill": (
                    json!({
                        "id": 0,
                        "type": ""
                    })
                ),
                "status": "",
                "total_vat": json!({}),
                "total_vat_exclusive": json!({}),
                "total_vat_inclusive": json!({}),
                "updated": "",
                "vat_number": ""
            }),
            "DraftPayment": json!({
                "entries": (
                    json!({
                        "alias": json!({}),
                        "amount": json!({}),
                        "attachment": (
                            json!({
                                "id": 0,
                                "monetary_account_id": 0
                            })
                        ),
                        "counterparty_alias": json!({}),
                        "description": "",
                        "id": 0,
                        "merchant_reference": "",
                        "type": ""
                    })
                ),
                "number_of_required_accepts": 0,
                "previous_updated_timestamp": "",
                "schedule": json!({
                    "object": json!({
                        "Payment": json!({
                            "address_billing": json!({}),
                            "address_shipping": json!({}),
                            "alias": json!({}),
                            "allow_bunqto": false,
                            "amount": json!({}),
                            "attachment": (json!({})),
                            "balance_after_mutation": json!({}),
                            "batch_id": 0,
                            "bunqto_expiry": "",
                            "bunqto_share_url": "",
                            "bunqto_status": "",
                            "bunqto_sub_status": "",
                            "bunqto_time_responded": "",
                            "counterparty_alias": json!({}),
                            "created": "",
                            "description": "",
                            "geolocation": json!({
                                "altitude": 0,
                                "latitude": 0,
                                "longitude": 0,
                                "radius": 0
                            }),
                            "id": 0,
                            "merchant_reference": "",
                            "monetary_account_id": 0,
                            "payment_auto_allocate_instance": json!({
                                "created": "",
                                "error_message": (),
                                "id": 0,
                                "payment_auto_allocate_id": 0,
                                "payment_batch": json!({"payments": json!({"Payment": ()})}),
                                "payment_id": 0,
                                "status": "",
                                "updated": ""
                            }),
                            "request_reference_split_the_bill": (json!({})),
                            "scheduled_id": 0,
                            "sub_type": "",
                            "type": "",
                            "updated": ""
                        }),
                        "PaymentBatch": json!({})
                    }),
                    "recurrence_size": 0,
                    "recurrence_unit": "",
                    "status": "",
                    "time_end": "",
                    "time_start": ""
                }),
                "status": ""
            }),
            "MasterCardAction": json!({
                "alias": json!({}),
                "all_mastercard_action_refund": (
                    json!({
                        "additional_information": json!({
                            "attachment": (json!({"id": 0})),
                            "category": "",
                            "comment": "",
                            "reason": "",
                            "terms_and_conditions": ""
                        }),
                        "alias": json!({}),
                        "amount": json!({}),
                        "attachment": (json!({})),
                        "category": "",
                        "comment": "",
                        "counterparty_alias": json!({}),
                        "created": "",
                        "description": "",
                        "id": 0,
                        "label_card": json!({
                            "expiry_date": "",
                            "label_user": json!({}),
                            "second_line": "",
                            "status": "",
                            "type": "",
                            "uuid": ""
                        }),
                        "label_user_creator": json!({}),
                        "mastercard_action_id": 0,
                        "reason": "",
                        "reference_mastercard_action_event": (json!({"event_id": 0})),
                        "status": "",
                        "status_description": "",
                        "status_description_translated": "",
                        "status_together_url": "",
                        "sub_type": "",
                        "terms_and_conditions": "",
                        "time_refund": "",
                        "type": "",
                        "updated": ""
                    })
                ),
                "amount_billing": json!({}),
                "amount_converted": json!({}),
                "amount_fee": json!({}),
                "amount_local": json!({}),
                "amount_original_billing": json!({}),
                "amount_original_local": json!({}),
                "applied_limit": "",
                "authorisation_status": "",
                "authorisation_type": "",
                "card_authorisation_id_response": "",
                "card_id": 0,
                "city": "",
                "clearing_expiry_time": "",
                "clearing_status": "",
                "counterparty_alias": json!({}),
                "decision": "",
                "decision_description": "",
                "decision_description_translated": "",
                "decision_together_url": "",
                "description": "",
                "eligible_whitelist_id": 0,
                "id": 0,
                "label_card": json!({}),
                "maturity_date": "",
                "monetary_account_id": 0,
                "pan_entry_mode_user": "",
                "payment_status": "",
                "pos_card_holder_presence": "",
                "pos_card_presence": "",
                "request_reference_split_the_bill": (json!({})),
                "reservation_expiry_time": "",
                "secure_code_id": 0,
                "settlement_status": "",
                "token_status": "",
                "wallet_provider_id": ""
            }),
            "Payment": json!({}),
            "PaymentBatch": json!({}),
            "RequestResponse": json!({
                "address_billing": json!({}),
                "address_shipping": json!({}),
                "alias": json!({}),
                "amount_inquired": json!({}),
                "amount_responded": json!({}),
                "attachment": (
                    json!({
                        "content_type": "",
                        "description": "",
                        "urls": (
                            json!({
                                "type": "",
                                "url": ""
                            })
                        )
                    })
                ),
                "counterparty_alias": json!({}),
                "created": "",
                "credit_scheme_identifier": "",
                "description": "",
                "eligible_whitelist_id": 0,
                "event_id": 0,
                "geolocation": json!({}),
                "id": 0,
                "mandate_identifier": "",
                "minimum_age": 0,
                "monetary_account_id": 0,
                "redirect_url": "",
                "request_reference_split_the_bill": (json!({})),
                "require_address": "",
                "status": "",
                "sub_type": "",
                "time_expiry": "",
                "time_refund_requested": "",
                "time_refunded": "",
                "time_responded": "",
                "type": "",
                "updated": "",
                "user_refund_requested": json!({})
            }),
            "ScheduleInstance": json!({
                "error_message": (),
                "request_reference_split_the_bill": (json!({})),
                "result_object": json!({
                    "Payment": json!({}),
                    "PaymentBatch": json!({})
                }),
                "scheduled_object": json!({}),
                "state": "",
                "time_end": "",
                "time_start": ""
            }),
            "TransferwisePayment": json!({
                "alias": json!({}),
                "amount_source": json!({}),
                "amount_target": json!({}),
                "counterparty_alias": json!({}),
                "monetary_account_id": "",
                "pay_in_reference": "",
                "quote": json!({
                    "amount_fee": json!({}),
                    "amount_source": json!({}),
                    "amount_target": json!({}),
                    "created": "",
                    "currency_source": "",
                    "currency_target": "",
                    "id": 0,
                    "quote_id": "",
                    "rate": "",
                    "time_delivery_estimate": "",
                    "time_expiry": "",
                    "updated": ""
                }),
                "rate": "",
                "recipient_id": "",
                "reference": "",
                "status": "",
                "status_transferwise": "",
                "status_transferwise_issue": "",
                "sub_status": "",
                "time_delivery_estimate": ""
            }),
            "WhitelistResult": json!({
                "error_message": (),
                "id": 0,
                "monetary_account_paying_id": 0,
                "object": json!({
                    "draftPayment": json!({}),
                    "id": 0,
                    "requestResponse": json!({})
                }),
                "request_reference_split_the_bill": (json!({})),
                "status": "",
                "sub_status": "",
                "whitelist": json!({})
            })
        }),
        "request_inquiries": (
            json!({
                "address_billing": json!({}),
                "address_shipping": json!({}),
                "allow_amount_higher": false,
                "allow_amount_lower": false,
                "allow_bunqme": false,
                "amount_inquired": json!({}),
                "amount_responded": json!({}),
                "attachment": (json!({"id": 0})),
                "batch_id": 0,
                "bunqme_share_url": "",
                "counterparty_alias": json!({}),
                "created": "",
                "description": "",
                "event_id": 0,
                "geolocation": json!({}),
                "id": 0,
                "merchant_reference": "",
                "minimum_age": 0,
                "monetary_account_id": 0,
                "redirect_url": "",
                "reference_split_the_bill": json!({}),
                "require_address": "",
                "scheduled_id": 0,
                "status": "",
                "time_expiry": "",
                "time_responded": "",
                "updated": "",
                "user_alias_created": json!({}),
                "user_alias_revoked": json!({}),
                "want_tip": false
            })
        ),
        "status": "",
        "total_amount_inquired": json!({})
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "event_id": 0,
  "reference_split_the_bill": {
    "BillingInvoice": {
      "address": {
        "city": "",
        "country": "",
        "extra": "",
        "house_number": "",
        "is_user_address_updated": false,
        "mailbox_name": "",
        "po_box": "",
        "postal_code": "",
        "province": "",
        "street": ""
      },
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "category": "",
      "chamber_of_commerce_number": "",
      "counterparty_address": {},
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "external_url": "",
      "group": [
        {
          "instance_description": "",
          "item": [
            {
              "billing_date": "",
              "id": 0,
              "quantity": 0,
              "total_vat_exclusive": {
                "currency": "",
                "value": ""
              },
              "total_vat_inclusive": {},
              "type_description": "",
              "type_description_translated": "",
              "unit_vat_exclusive": {},
              "unit_vat_inclusive": {},
              "vat": 0
            }
          ],
          "product_vat_exclusive": {},
          "product_vat_inclusive": {},
          "type": "",
          "type_description": "",
          "type_description_translated": ""
        }
      ],
      "id": 0,
      "invoice_date": "",
      "invoice_number": "",
      "request_reference_split_the_bill": [
        {
          "id": 0,
          "type": ""
        }
      ],
      "status": "",
      "total_vat": {},
      "total_vat_exclusive": {},
      "total_vat_inclusive": {},
      "updated": "",
      "vat_number": ""
    },
    "DraftPayment": {
      "entries": [
        {
          "alias": {},
          "amount": {},
          "attachment": [
            {
              "id": 0,
              "monetary_account_id": 0
            }
          ],
          "counterparty_alias": {},
          "description": "",
          "id": 0,
          "merchant_reference": "",
          "type": ""
        }
      ],
      "number_of_required_accepts": 0,
      "previous_updated_timestamp": "",
      "schedule": {
        "object": {
          "Payment": {
            "address_billing": {},
            "address_shipping": {},
            "alias": {},
            "allow_bunqto": false,
            "amount": {},
            "attachment": [
              {}
            ],
            "balance_after_mutation": {},
            "batch_id": 0,
            "bunqto_expiry": "",
            "bunqto_share_url": "",
            "bunqto_status": "",
            "bunqto_sub_status": "",
            "bunqto_time_responded": "",
            "counterparty_alias": {},
            "created": "",
            "description": "",
            "geolocation": {
              "altitude": 0,
              "latitude": 0,
              "longitude": 0,
              "radius": 0
            },
            "id": 0,
            "merchant_reference": "",
            "monetary_account_id": 0,
            "payment_auto_allocate_instance": {
              "created": "",
              "error_message": [],
              "id": 0,
              "payment_auto_allocate_id": 0,
              "payment_batch": {
                "payments": {
                  "Payment": []
                }
              },
              "payment_id": 0,
              "status": "",
              "updated": ""
            },
            "request_reference_split_the_bill": [
              {}
            ],
            "scheduled_id": 0,
            "sub_type": "",
            "type": "",
            "updated": ""
          },
          "PaymentBatch": {}
        },
        "recurrence_size": 0,
        "recurrence_unit": "",
        "status": "",
        "time_end": "",
        "time_start": ""
      },
      "status": ""
    },
    "MasterCardAction": {
      "alias": {},
      "all_mastercard_action_refund": [
        {
          "additional_information": {
            "attachment": [
              {
                "id": 0
              }
            ],
            "category": "",
            "comment": "",
            "reason": "",
            "terms_and_conditions": ""
          },
          "alias": {},
          "amount": {},
          "attachment": [
            {}
          ],
          "category": "",
          "comment": "",
          "counterparty_alias": {},
          "created": "",
          "description": "",
          "id": 0,
          "label_card": {
            "expiry_date": "",
            "label_user": {},
            "second_line": "",
            "status": "",
            "type": "",
            "uuid": ""
          },
          "label_user_creator": {},
          "mastercard_action_id": 0,
          "reason": "",
          "reference_mastercard_action_event": [
            {
              "event_id": 0
            }
          ],
          "status": "",
          "status_description": "",
          "status_description_translated": "",
          "status_together_url": "",
          "sub_type": "",
          "terms_and_conditions": "",
          "time_refund": "",
          "type": "",
          "updated": ""
        }
      ],
      "amount_billing": {},
      "amount_converted": {},
      "amount_fee": {},
      "amount_local": {},
      "amount_original_billing": {},
      "amount_original_local": {},
      "applied_limit": "",
      "authorisation_status": "",
      "authorisation_type": "",
      "card_authorisation_id_response": "",
      "card_id": 0,
      "city": "",
      "clearing_expiry_time": "",
      "clearing_status": "",
      "counterparty_alias": {},
      "decision": "",
      "decision_description": "",
      "decision_description_translated": "",
      "decision_together_url": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "id": 0,
      "label_card": {},
      "maturity_date": "",
      "monetary_account_id": 0,
      "pan_entry_mode_user": "",
      "payment_status": "",
      "pos_card_holder_presence": "",
      "pos_card_presence": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "reservation_expiry_time": "",
      "secure_code_id": 0,
      "settlement_status": "",
      "token_status": "",
      "wallet_provider_id": ""
    },
    "Payment": {},
    "PaymentBatch": {},
    "RequestResponse": {
      "address_billing": {},
      "address_shipping": {},
      "alias": {},
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "content_type": "",
          "description": "",
          "urls": [
            {
              "type": "",
              "url": ""
            }
          ]
        }
      ],
      "counterparty_alias": {},
      "created": "",
      "credit_scheme_identifier": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "mandate_identifier": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "require_address": "",
      "status": "",
      "sub_type": "",
      "time_expiry": "",
      "time_refund_requested": "",
      "time_refunded": "",
      "time_responded": "",
      "type": "",
      "updated": "",
      "user_refund_requested": {}
    },
    "ScheduleInstance": {
      "error_message": [],
      "request_reference_split_the_bill": [
        {}
      ],
      "result_object": {
        "Payment": {},
        "PaymentBatch": {}
      },
      "scheduled_object": {},
      "state": "",
      "time_end": "",
      "time_start": ""
    },
    "TransferwisePayment": {
      "alias": {},
      "amount_source": {},
      "amount_target": {},
      "counterparty_alias": {},
      "monetary_account_id": "",
      "pay_in_reference": "",
      "quote": {
        "amount_fee": {},
        "amount_source": {},
        "amount_target": {},
        "created": "",
        "currency_source": "",
        "currency_target": "",
        "id": 0,
        "quote_id": "",
        "rate": "",
        "time_delivery_estimate": "",
        "time_expiry": "",
        "updated": ""
      },
      "rate": "",
      "recipient_id": "",
      "reference": "",
      "status": "",
      "status_transferwise": "",
      "status_transferwise_issue": "",
      "sub_status": "",
      "time_delivery_estimate": ""
    },
    "WhitelistResult": {
      "error_message": [],
      "id": 0,
      "monetary_account_paying_id": 0,
      "object": {
        "draftPayment": {},
        "id": 0,
        "requestResponse": {}
      },
      "request_reference_split_the_bill": [
        {}
      ],
      "status": "",
      "sub_status": "",
      "whitelist": {}
    }
  },
  "request_inquiries": [
    {
      "address_billing": {},
      "address_shipping": {},
      "allow_amount_higher": false,
      "allow_amount_lower": false,
      "allow_bunqme": false,
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "id": 0
        }
      ],
      "batch_id": 0,
      "bunqme_share_url": "",
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "merchant_reference": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "reference_split_the_bill": {},
      "require_address": "",
      "scheduled_id": 0,
      "status": "",
      "time_expiry": "",
      "time_responded": "",
      "updated": "",
      "user_alias_created": {},
      "user_alias_revoked": {},
      "want_tip": false
    }
  ],
  "status": "",
  "total_amount_inquired": {}
}'
echo '{
  "event_id": 0,
  "reference_split_the_bill": {
    "BillingInvoice": {
      "address": {
        "city": "",
        "country": "",
        "extra": "",
        "house_number": "",
        "is_user_address_updated": false,
        "mailbox_name": "",
        "po_box": "",
        "postal_code": "",
        "province": "",
        "street": ""
      },
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "category": "",
      "chamber_of_commerce_number": "",
      "counterparty_address": {},
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "external_url": "",
      "group": [
        {
          "instance_description": "",
          "item": [
            {
              "billing_date": "",
              "id": 0,
              "quantity": 0,
              "total_vat_exclusive": {
                "currency": "",
                "value": ""
              },
              "total_vat_inclusive": {},
              "type_description": "",
              "type_description_translated": "",
              "unit_vat_exclusive": {},
              "unit_vat_inclusive": {},
              "vat": 0
            }
          ],
          "product_vat_exclusive": {},
          "product_vat_inclusive": {},
          "type": "",
          "type_description": "",
          "type_description_translated": ""
        }
      ],
      "id": 0,
      "invoice_date": "",
      "invoice_number": "",
      "request_reference_split_the_bill": [
        {
          "id": 0,
          "type": ""
        }
      ],
      "status": "",
      "total_vat": {},
      "total_vat_exclusive": {},
      "total_vat_inclusive": {},
      "updated": "",
      "vat_number": ""
    },
    "DraftPayment": {
      "entries": [
        {
          "alias": {},
          "amount": {},
          "attachment": [
            {
              "id": 0,
              "monetary_account_id": 0
            }
          ],
          "counterparty_alias": {},
          "description": "",
          "id": 0,
          "merchant_reference": "",
          "type": ""
        }
      ],
      "number_of_required_accepts": 0,
      "previous_updated_timestamp": "",
      "schedule": {
        "object": {
          "Payment": {
            "address_billing": {},
            "address_shipping": {},
            "alias": {},
            "allow_bunqto": false,
            "amount": {},
            "attachment": [
              {}
            ],
            "balance_after_mutation": {},
            "batch_id": 0,
            "bunqto_expiry": "",
            "bunqto_share_url": "",
            "bunqto_status": "",
            "bunqto_sub_status": "",
            "bunqto_time_responded": "",
            "counterparty_alias": {},
            "created": "",
            "description": "",
            "geolocation": {
              "altitude": 0,
              "latitude": 0,
              "longitude": 0,
              "radius": 0
            },
            "id": 0,
            "merchant_reference": "",
            "monetary_account_id": 0,
            "payment_auto_allocate_instance": {
              "created": "",
              "error_message": [],
              "id": 0,
              "payment_auto_allocate_id": 0,
              "payment_batch": {
                "payments": {
                  "Payment": []
                }
              },
              "payment_id": 0,
              "status": "",
              "updated": ""
            },
            "request_reference_split_the_bill": [
              {}
            ],
            "scheduled_id": 0,
            "sub_type": "",
            "type": "",
            "updated": ""
          },
          "PaymentBatch": {}
        },
        "recurrence_size": 0,
        "recurrence_unit": "",
        "status": "",
        "time_end": "",
        "time_start": ""
      },
      "status": ""
    },
    "MasterCardAction": {
      "alias": {},
      "all_mastercard_action_refund": [
        {
          "additional_information": {
            "attachment": [
              {
                "id": 0
              }
            ],
            "category": "",
            "comment": "",
            "reason": "",
            "terms_and_conditions": ""
          },
          "alias": {},
          "amount": {},
          "attachment": [
            {}
          ],
          "category": "",
          "comment": "",
          "counterparty_alias": {},
          "created": "",
          "description": "",
          "id": 0,
          "label_card": {
            "expiry_date": "",
            "label_user": {},
            "second_line": "",
            "status": "",
            "type": "",
            "uuid": ""
          },
          "label_user_creator": {},
          "mastercard_action_id": 0,
          "reason": "",
          "reference_mastercard_action_event": [
            {
              "event_id": 0
            }
          ],
          "status": "",
          "status_description": "",
          "status_description_translated": "",
          "status_together_url": "",
          "sub_type": "",
          "terms_and_conditions": "",
          "time_refund": "",
          "type": "",
          "updated": ""
        }
      ],
      "amount_billing": {},
      "amount_converted": {},
      "amount_fee": {},
      "amount_local": {},
      "amount_original_billing": {},
      "amount_original_local": {},
      "applied_limit": "",
      "authorisation_status": "",
      "authorisation_type": "",
      "card_authorisation_id_response": "",
      "card_id": 0,
      "city": "",
      "clearing_expiry_time": "",
      "clearing_status": "",
      "counterparty_alias": {},
      "decision": "",
      "decision_description": "",
      "decision_description_translated": "",
      "decision_together_url": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "id": 0,
      "label_card": {},
      "maturity_date": "",
      "monetary_account_id": 0,
      "pan_entry_mode_user": "",
      "payment_status": "",
      "pos_card_holder_presence": "",
      "pos_card_presence": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "reservation_expiry_time": "",
      "secure_code_id": 0,
      "settlement_status": "",
      "token_status": "",
      "wallet_provider_id": ""
    },
    "Payment": {},
    "PaymentBatch": {},
    "RequestResponse": {
      "address_billing": {},
      "address_shipping": {},
      "alias": {},
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "content_type": "",
          "description": "",
          "urls": [
            {
              "type": "",
              "url": ""
            }
          ]
        }
      ],
      "counterparty_alias": {},
      "created": "",
      "credit_scheme_identifier": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "mandate_identifier": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "require_address": "",
      "status": "",
      "sub_type": "",
      "time_expiry": "",
      "time_refund_requested": "",
      "time_refunded": "",
      "time_responded": "",
      "type": "",
      "updated": "",
      "user_refund_requested": {}
    },
    "ScheduleInstance": {
      "error_message": [],
      "request_reference_split_the_bill": [
        {}
      ],
      "result_object": {
        "Payment": {},
        "PaymentBatch": {}
      },
      "scheduled_object": {},
      "state": "",
      "time_end": "",
      "time_start": ""
    },
    "TransferwisePayment": {
      "alias": {},
      "amount_source": {},
      "amount_target": {},
      "counterparty_alias": {},
      "monetary_account_id": "",
      "pay_in_reference": "",
      "quote": {
        "amount_fee": {},
        "amount_source": {},
        "amount_target": {},
        "created": "",
        "currency_source": "",
        "currency_target": "",
        "id": 0,
        "quote_id": "",
        "rate": "",
        "time_delivery_estimate": "",
        "time_expiry": "",
        "updated": ""
      },
      "rate": "",
      "recipient_id": "",
      "reference": "",
      "status": "",
      "status_transferwise": "",
      "status_transferwise_issue": "",
      "sub_status": "",
      "time_delivery_estimate": ""
    },
    "WhitelistResult": {
      "error_message": [],
      "id": 0,
      "monetary_account_paying_id": 0,
      "object": {
        "draftPayment": {},
        "id": 0,
        "requestResponse": {}
      },
      "request_reference_split_the_bill": [
        {}
      ],
      "status": "",
      "sub_status": "",
      "whitelist": {}
    }
  },
  "request_inquiries": [
    {
      "address_billing": {},
      "address_shipping": {},
      "allow_amount_higher": false,
      "allow_amount_lower": false,
      "allow_bunqme": false,
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "id": 0
        }
      ],
      "batch_id": 0,
      "bunqme_share_url": "",
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "merchant_reference": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "reference_split_the_bill": {},
      "require_address": "",
      "scheduled_id": 0,
      "status": "",
      "time_expiry": "",
      "time_responded": "",
      "updated": "",
      "user_alias_created": {},
      "user_alias_revoked": {},
      "want_tip": false
    }
  ],
  "status": "",
  "total_amount_inquired": {}
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "event_id": 0,\n  "reference_split_the_bill": {\n    "BillingInvoice": {\n      "address": {\n        "city": "",\n        "country": "",\n        "extra": "",\n        "house_number": "",\n        "is_user_address_updated": false,\n        "mailbox_name": "",\n        "po_box": "",\n        "postal_code": "",\n        "province": "",\n        "street": ""\n      },\n      "alias": {\n        "avatar": {\n          "anchor_uuid": "",\n          "image": [\n            {\n              "attachment_public_uuid": "",\n              "content_type": "",\n              "height": 0,\n              "width": 0\n            }\n          ],\n          "style": "",\n          "uuid": ""\n        },\n        "bunq_me": {\n          "name": "",\n          "service": "",\n          "type": "",\n          "value": ""\n        },\n        "country": "",\n        "display_name": "",\n        "iban": "",\n        "is_light": false,\n        "label_user": {\n          "avatar": {},\n          "country": "",\n          "display_name": "",\n          "public_nick_name": "",\n          "uuid": ""\n        },\n        "merchant_category_code": "",\n        "swift_account_number": "",\n        "swift_bic": "",\n        "transferwise_account_number": "",\n        "transferwise_bank_code": ""\n      },\n      "category": "",\n      "chamber_of_commerce_number": "",\n      "counterparty_address": {},\n      "counterparty_alias": {},\n      "created": "",\n      "description": "",\n      "external_url": "",\n      "group": [\n        {\n          "instance_description": "",\n          "item": [\n            {\n              "billing_date": "",\n              "id": 0,\n              "quantity": 0,\n              "total_vat_exclusive": {\n                "currency": "",\n                "value": ""\n              },\n              "total_vat_inclusive": {},\n              "type_description": "",\n              "type_description_translated": "",\n              "unit_vat_exclusive": {},\n              "unit_vat_inclusive": {},\n              "vat": 0\n            }\n          ],\n          "product_vat_exclusive": {},\n          "product_vat_inclusive": {},\n          "type": "",\n          "type_description": "",\n          "type_description_translated": ""\n        }\n      ],\n      "id": 0,\n      "invoice_date": "",\n      "invoice_number": "",\n      "request_reference_split_the_bill": [\n        {\n          "id": 0,\n          "type": ""\n        }\n      ],\n      "status": "",\n      "total_vat": {},\n      "total_vat_exclusive": {},\n      "total_vat_inclusive": {},\n      "updated": "",\n      "vat_number": ""\n    },\n    "DraftPayment": {\n      "entries": [\n        {\n          "alias": {},\n          "amount": {},\n          "attachment": [\n            {\n              "id": 0,\n              "monetary_account_id": 0\n            }\n          ],\n          "counterparty_alias": {},\n          "description": "",\n          "id": 0,\n          "merchant_reference": "",\n          "type": ""\n        }\n      ],\n      "number_of_required_accepts": 0,\n      "previous_updated_timestamp": "",\n      "schedule": {\n        "object": {\n          "Payment": {\n            "address_billing": {},\n            "address_shipping": {},\n            "alias": {},\n            "allow_bunqto": false,\n            "amount": {},\n            "attachment": [\n              {}\n            ],\n            "balance_after_mutation": {},\n            "batch_id": 0,\n            "bunqto_expiry": "",\n            "bunqto_share_url": "",\n            "bunqto_status": "",\n            "bunqto_sub_status": "",\n            "bunqto_time_responded": "",\n            "counterparty_alias": {},\n            "created": "",\n            "description": "",\n            "geolocation": {\n              "altitude": 0,\n              "latitude": 0,\n              "longitude": 0,\n              "radius": 0\n            },\n            "id": 0,\n            "merchant_reference": "",\n            "monetary_account_id": 0,\n            "payment_auto_allocate_instance": {\n              "created": "",\n              "error_message": [],\n              "id": 0,\n              "payment_auto_allocate_id": 0,\n              "payment_batch": {\n                "payments": {\n                  "Payment": []\n                }\n              },\n              "payment_id": 0,\n              "status": "",\n              "updated": ""\n            },\n            "request_reference_split_the_bill": [\n              {}\n            ],\n            "scheduled_id": 0,\n            "sub_type": "",\n            "type": "",\n            "updated": ""\n          },\n          "PaymentBatch": {}\n        },\n        "recurrence_size": 0,\n        "recurrence_unit": "",\n        "status": "",\n        "time_end": "",\n        "time_start": ""\n      },\n      "status": ""\n    },\n    "MasterCardAction": {\n      "alias": {},\n      "all_mastercard_action_refund": [\n        {\n          "additional_information": {\n            "attachment": [\n              {\n                "id": 0\n              }\n            ],\n            "category": "",\n            "comment": "",\n            "reason": "",\n            "terms_and_conditions": ""\n          },\n          "alias": {},\n          "amount": {},\n          "attachment": [\n            {}\n          ],\n          "category": "",\n          "comment": "",\n          "counterparty_alias": {},\n          "created": "",\n          "description": "",\n          "id": 0,\n          "label_card": {\n            "expiry_date": "",\n            "label_user": {},\n            "second_line": "",\n            "status": "",\n            "type": "",\n            "uuid": ""\n          },\n          "label_user_creator": {},\n          "mastercard_action_id": 0,\n          "reason": "",\n          "reference_mastercard_action_event": [\n            {\n              "event_id": 0\n            }\n          ],\n          "status": "",\n          "status_description": "",\n          "status_description_translated": "",\n          "status_together_url": "",\n          "sub_type": "",\n          "terms_and_conditions": "",\n          "time_refund": "",\n          "type": "",\n          "updated": ""\n        }\n      ],\n      "amount_billing": {},\n      "amount_converted": {},\n      "amount_fee": {},\n      "amount_local": {},\n      "amount_original_billing": {},\n      "amount_original_local": {},\n      "applied_limit": "",\n      "authorisation_status": "",\n      "authorisation_type": "",\n      "card_authorisation_id_response": "",\n      "card_id": 0,\n      "city": "",\n      "clearing_expiry_time": "",\n      "clearing_status": "",\n      "counterparty_alias": {},\n      "decision": "",\n      "decision_description": "",\n      "decision_description_translated": "",\n      "decision_together_url": "",\n      "description": "",\n      "eligible_whitelist_id": 0,\n      "id": 0,\n      "label_card": {},\n      "maturity_date": "",\n      "monetary_account_id": 0,\n      "pan_entry_mode_user": "",\n      "payment_status": "",\n      "pos_card_holder_presence": "",\n      "pos_card_presence": "",\n      "request_reference_split_the_bill": [\n        {}\n      ],\n      "reservation_expiry_time": "",\n      "secure_code_id": 0,\n      "settlement_status": "",\n      "token_status": "",\n      "wallet_provider_id": ""\n    },\n    "Payment": {},\n    "PaymentBatch": {},\n    "RequestResponse": {\n      "address_billing": {},\n      "address_shipping": {},\n      "alias": {},\n      "amount_inquired": {},\n      "amount_responded": {},\n      "attachment": [\n        {\n          "content_type": "",\n          "description": "",\n          "urls": [\n            {\n              "type": "",\n              "url": ""\n            }\n          ]\n        }\n      ],\n      "counterparty_alias": {},\n      "created": "",\n      "credit_scheme_identifier": "",\n      "description": "",\n      "eligible_whitelist_id": 0,\n      "event_id": 0,\n      "geolocation": {},\n      "id": 0,\n      "mandate_identifier": "",\n      "minimum_age": 0,\n      "monetary_account_id": 0,\n      "redirect_url": "",\n      "request_reference_split_the_bill": [\n        {}\n      ],\n      "require_address": "",\n      "status": "",\n      "sub_type": "",\n      "time_expiry": "",\n      "time_refund_requested": "",\n      "time_refunded": "",\n      "time_responded": "",\n      "type": "",\n      "updated": "",\n      "user_refund_requested": {}\n    },\n    "ScheduleInstance": {\n      "error_message": [],\n      "request_reference_split_the_bill": [\n        {}\n      ],\n      "result_object": {\n        "Payment": {},\n        "PaymentBatch": {}\n      },\n      "scheduled_object": {},\n      "state": "",\n      "time_end": "",\n      "time_start": ""\n    },\n    "TransferwisePayment": {\n      "alias": {},\n      "amount_source": {},\n      "amount_target": {},\n      "counterparty_alias": {},\n      "monetary_account_id": "",\n      "pay_in_reference": "",\n      "quote": {\n        "amount_fee": {},\n        "amount_source": {},\n        "amount_target": {},\n        "created": "",\n        "currency_source": "",\n        "currency_target": "",\n        "id": 0,\n        "quote_id": "",\n        "rate": "",\n        "time_delivery_estimate": "",\n        "time_expiry": "",\n        "updated": ""\n      },\n      "rate": "",\n      "recipient_id": "",\n      "reference": "",\n      "status": "",\n      "status_transferwise": "",\n      "status_transferwise_issue": "",\n      "sub_status": "",\n      "time_delivery_estimate": ""\n    },\n    "WhitelistResult": {\n      "error_message": [],\n      "id": 0,\n      "monetary_account_paying_id": 0,\n      "object": {\n        "draftPayment": {},\n        "id": 0,\n        "requestResponse": {}\n      },\n      "request_reference_split_the_bill": [\n        {}\n      ],\n      "status": "",\n      "sub_status": "",\n      "whitelist": {}\n    }\n  },\n  "request_inquiries": [\n    {\n      "address_billing": {},\n      "address_shipping": {},\n      "allow_amount_higher": false,\n      "allow_amount_lower": false,\n      "allow_bunqme": false,\n      "amount_inquired": {},\n      "amount_responded": {},\n      "attachment": [\n        {\n          "id": 0\n        }\n      ],\n      "batch_id": 0,\n      "bunqme_share_url": "",\n      "counterparty_alias": {},\n      "created": "",\n      "description": "",\n      "event_id": 0,\n      "geolocation": {},\n      "id": 0,\n      "merchant_reference": "",\n      "minimum_age": 0,\n      "monetary_account_id": 0,\n      "redirect_url": "",\n      "reference_split_the_bill": {},\n      "require_address": "",\n      "scheduled_id": 0,\n      "status": "",\n      "time_expiry": "",\n      "time_responded": "",\n      "updated": "",\n      "user_alias_created": {},\n      "user_alias_revoked": {},\n      "want_tip": false\n    }\n  ],\n  "status": "",\n  "total_amount_inquired": {}\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "event_id": 0,
  "reference_split_the_bill": [
    "BillingInvoice": [
      "address": [
        "city": "",
        "country": "",
        "extra": "",
        "house_number": "",
        "is_user_address_updated": false,
        "mailbox_name": "",
        "po_box": "",
        "postal_code": "",
        "province": "",
        "street": ""
      ],
      "alias": [
        "avatar": [
          "anchor_uuid": "",
          "image": [
            [
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            ]
          ],
          "style": "",
          "uuid": ""
        ],
        "bunq_me": [
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        ],
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": [
          "avatar": [],
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        ],
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      ],
      "category": "",
      "chamber_of_commerce_number": "",
      "counterparty_address": [],
      "counterparty_alias": [],
      "created": "",
      "description": "",
      "external_url": "",
      "group": [
        [
          "instance_description": "",
          "item": [
            [
              "billing_date": "",
              "id": 0,
              "quantity": 0,
              "total_vat_exclusive": [
                "currency": "",
                "value": ""
              ],
              "total_vat_inclusive": [],
              "type_description": "",
              "type_description_translated": "",
              "unit_vat_exclusive": [],
              "unit_vat_inclusive": [],
              "vat": 0
            ]
          ],
          "product_vat_exclusive": [],
          "product_vat_inclusive": [],
          "type": "",
          "type_description": "",
          "type_description_translated": ""
        ]
      ],
      "id": 0,
      "invoice_date": "",
      "invoice_number": "",
      "request_reference_split_the_bill": [
        [
          "id": 0,
          "type": ""
        ]
      ],
      "status": "",
      "total_vat": [],
      "total_vat_exclusive": [],
      "total_vat_inclusive": [],
      "updated": "",
      "vat_number": ""
    ],
    "DraftPayment": [
      "entries": [
        [
          "alias": [],
          "amount": [],
          "attachment": [
            [
              "id": 0,
              "monetary_account_id": 0
            ]
          ],
          "counterparty_alias": [],
          "description": "",
          "id": 0,
          "merchant_reference": "",
          "type": ""
        ]
      ],
      "number_of_required_accepts": 0,
      "previous_updated_timestamp": "",
      "schedule": [
        "object": [
          "Payment": [
            "address_billing": [],
            "address_shipping": [],
            "alias": [],
            "allow_bunqto": false,
            "amount": [],
            "attachment": [[]],
            "balance_after_mutation": [],
            "batch_id": 0,
            "bunqto_expiry": "",
            "bunqto_share_url": "",
            "bunqto_status": "",
            "bunqto_sub_status": "",
            "bunqto_time_responded": "",
            "counterparty_alias": [],
            "created": "",
            "description": "",
            "geolocation": [
              "altitude": 0,
              "latitude": 0,
              "longitude": 0,
              "radius": 0
            ],
            "id": 0,
            "merchant_reference": "",
            "monetary_account_id": 0,
            "payment_auto_allocate_instance": [
              "created": "",
              "error_message": [],
              "id": 0,
              "payment_auto_allocate_id": 0,
              "payment_batch": ["payments": ["Payment": []]],
              "payment_id": 0,
              "status": "",
              "updated": ""
            ],
            "request_reference_split_the_bill": [[]],
            "scheduled_id": 0,
            "sub_type": "",
            "type": "",
            "updated": ""
          ],
          "PaymentBatch": []
        ],
        "recurrence_size": 0,
        "recurrence_unit": "",
        "status": "",
        "time_end": "",
        "time_start": ""
      ],
      "status": ""
    ],
    "MasterCardAction": [
      "alias": [],
      "all_mastercard_action_refund": [
        [
          "additional_information": [
            "attachment": [["id": 0]],
            "category": "",
            "comment": "",
            "reason": "",
            "terms_and_conditions": ""
          ],
          "alias": [],
          "amount": [],
          "attachment": [[]],
          "category": "",
          "comment": "",
          "counterparty_alias": [],
          "created": "",
          "description": "",
          "id": 0,
          "label_card": [
            "expiry_date": "",
            "label_user": [],
            "second_line": "",
            "status": "",
            "type": "",
            "uuid": ""
          ],
          "label_user_creator": [],
          "mastercard_action_id": 0,
          "reason": "",
          "reference_mastercard_action_event": [["event_id": 0]],
          "status": "",
          "status_description": "",
          "status_description_translated": "",
          "status_together_url": "",
          "sub_type": "",
          "terms_and_conditions": "",
          "time_refund": "",
          "type": "",
          "updated": ""
        ]
      ],
      "amount_billing": [],
      "amount_converted": [],
      "amount_fee": [],
      "amount_local": [],
      "amount_original_billing": [],
      "amount_original_local": [],
      "applied_limit": "",
      "authorisation_status": "",
      "authorisation_type": "",
      "card_authorisation_id_response": "",
      "card_id": 0,
      "city": "",
      "clearing_expiry_time": "",
      "clearing_status": "",
      "counterparty_alias": [],
      "decision": "",
      "decision_description": "",
      "decision_description_translated": "",
      "decision_together_url": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "id": 0,
      "label_card": [],
      "maturity_date": "",
      "monetary_account_id": 0,
      "pan_entry_mode_user": "",
      "payment_status": "",
      "pos_card_holder_presence": "",
      "pos_card_presence": "",
      "request_reference_split_the_bill": [[]],
      "reservation_expiry_time": "",
      "secure_code_id": 0,
      "settlement_status": "",
      "token_status": "",
      "wallet_provider_id": ""
    ],
    "Payment": [],
    "PaymentBatch": [],
    "RequestResponse": [
      "address_billing": [],
      "address_shipping": [],
      "alias": [],
      "amount_inquired": [],
      "amount_responded": [],
      "attachment": [
        [
          "content_type": "",
          "description": "",
          "urls": [
            [
              "type": "",
              "url": ""
            ]
          ]
        ]
      ],
      "counterparty_alias": [],
      "created": "",
      "credit_scheme_identifier": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "event_id": 0,
      "geolocation": [],
      "id": 0,
      "mandate_identifier": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "request_reference_split_the_bill": [[]],
      "require_address": "",
      "status": "",
      "sub_type": "",
      "time_expiry": "",
      "time_refund_requested": "",
      "time_refunded": "",
      "time_responded": "",
      "type": "",
      "updated": "",
      "user_refund_requested": []
    ],
    "ScheduleInstance": [
      "error_message": [],
      "request_reference_split_the_bill": [[]],
      "result_object": [
        "Payment": [],
        "PaymentBatch": []
      ],
      "scheduled_object": [],
      "state": "",
      "time_end": "",
      "time_start": ""
    ],
    "TransferwisePayment": [
      "alias": [],
      "amount_source": [],
      "amount_target": [],
      "counterparty_alias": [],
      "monetary_account_id": "",
      "pay_in_reference": "",
      "quote": [
        "amount_fee": [],
        "amount_source": [],
        "amount_target": [],
        "created": "",
        "currency_source": "",
        "currency_target": "",
        "id": 0,
        "quote_id": "",
        "rate": "",
        "time_delivery_estimate": "",
        "time_expiry": "",
        "updated": ""
      ],
      "rate": "",
      "recipient_id": "",
      "reference": "",
      "status": "",
      "status_transferwise": "",
      "status_transferwise_issue": "",
      "sub_status": "",
      "time_delivery_estimate": ""
    ],
    "WhitelistResult": [
      "error_message": [],
      "id": 0,
      "monetary_account_paying_id": 0,
      "object": [
        "draftPayment": [],
        "id": 0,
        "requestResponse": []
      ],
      "request_reference_split_the_bill": [[]],
      "status": "",
      "sub_status": "",
      "whitelist": []
    ]
  ],
  "request_inquiries": [
    [
      "address_billing": [],
      "address_shipping": [],
      "allow_amount_higher": false,
      "allow_amount_lower": false,
      "allow_bunqme": false,
      "amount_inquired": [],
      "amount_responded": [],
      "attachment": [["id": 0]],
      "batch_id": 0,
      "bunqme_share_url": "",
      "counterparty_alias": [],
      "created": "",
      "description": "",
      "event_id": 0,
      "geolocation": [],
      "id": 0,
      "merchant_reference": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "reference_split_the_bill": [],
      "require_address": "",
      "scheduled_id": 0,
      "status": "",
      "time_expiry": "",
      "time_responded": "",
      "updated": "",
      "user_alias_created": [],
      "user_alias_revoked": [],
      "want_tip": false
    ]
  ],
  "status": "",
  "total_amount_inquired": []
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_RequestInquiryBatch_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch" {:headers {:user-agent ""
                                                                                                                             :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_RequestInquiryBatch_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId" {:headers {:user-agent ""
                                                                                                                                     :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_RequestInquiryBatch_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
itemId
BODY json

{
  "event_id": 0,
  "reference_split_the_bill": {
    "BillingInvoice": {
      "address": {
        "city": "",
        "country": "",
        "extra": "",
        "house_number": "",
        "is_user_address_updated": false,
        "mailbox_name": "",
        "po_box": "",
        "postal_code": "",
        "province": "",
        "street": ""
      },
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "category": "",
      "chamber_of_commerce_number": "",
      "counterparty_address": {},
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "external_url": "",
      "group": [
        {
          "instance_description": "",
          "item": [
            {
              "billing_date": "",
              "id": 0,
              "quantity": 0,
              "total_vat_exclusive": {
                "currency": "",
                "value": ""
              },
              "total_vat_inclusive": {},
              "type_description": "",
              "type_description_translated": "",
              "unit_vat_exclusive": {},
              "unit_vat_inclusive": {},
              "vat": 0
            }
          ],
          "product_vat_exclusive": {},
          "product_vat_inclusive": {},
          "type": "",
          "type_description": "",
          "type_description_translated": ""
        }
      ],
      "id": 0,
      "invoice_date": "",
      "invoice_number": "",
      "request_reference_split_the_bill": [
        {
          "id": 0,
          "type": ""
        }
      ],
      "status": "",
      "total_vat": {},
      "total_vat_exclusive": {},
      "total_vat_inclusive": {},
      "updated": "",
      "vat_number": ""
    },
    "DraftPayment": {
      "entries": [
        {
          "alias": {},
          "amount": {},
          "attachment": [
            {
              "id": 0,
              "monetary_account_id": 0
            }
          ],
          "counterparty_alias": {},
          "description": "",
          "id": 0,
          "merchant_reference": "",
          "type": ""
        }
      ],
      "number_of_required_accepts": 0,
      "previous_updated_timestamp": "",
      "schedule": {
        "object": {
          "Payment": {
            "address_billing": {},
            "address_shipping": {},
            "alias": {},
            "allow_bunqto": false,
            "amount": {},
            "attachment": [
              {}
            ],
            "balance_after_mutation": {},
            "batch_id": 0,
            "bunqto_expiry": "",
            "bunqto_share_url": "",
            "bunqto_status": "",
            "bunqto_sub_status": "",
            "bunqto_time_responded": "",
            "counterparty_alias": {},
            "created": "",
            "description": "",
            "geolocation": {
              "altitude": 0,
              "latitude": 0,
              "longitude": 0,
              "radius": 0
            },
            "id": 0,
            "merchant_reference": "",
            "monetary_account_id": 0,
            "payment_auto_allocate_instance": {
              "created": "",
              "error_message": [],
              "id": 0,
              "payment_auto_allocate_id": 0,
              "payment_batch": {
                "payments": {
                  "Payment": []
                }
              },
              "payment_id": 0,
              "status": "",
              "updated": ""
            },
            "request_reference_split_the_bill": [
              {}
            ],
            "scheduled_id": 0,
            "sub_type": "",
            "type": "",
            "updated": ""
          },
          "PaymentBatch": {}
        },
        "recurrence_size": 0,
        "recurrence_unit": "",
        "status": "",
        "time_end": "",
        "time_start": ""
      },
      "status": ""
    },
    "MasterCardAction": {
      "alias": {},
      "all_mastercard_action_refund": [
        {
          "additional_information": {
            "attachment": [
              {
                "id": 0
              }
            ],
            "category": "",
            "comment": "",
            "reason": "",
            "terms_and_conditions": ""
          },
          "alias": {},
          "amount": {},
          "attachment": [
            {}
          ],
          "category": "",
          "comment": "",
          "counterparty_alias": {},
          "created": "",
          "description": "",
          "id": 0,
          "label_card": {
            "expiry_date": "",
            "label_user": {},
            "second_line": "",
            "status": "",
            "type": "",
            "uuid": ""
          },
          "label_user_creator": {},
          "mastercard_action_id": 0,
          "reason": "",
          "reference_mastercard_action_event": [
            {
              "event_id": 0
            }
          ],
          "status": "",
          "status_description": "",
          "status_description_translated": "",
          "status_together_url": "",
          "sub_type": "",
          "terms_and_conditions": "",
          "time_refund": "",
          "type": "",
          "updated": ""
        }
      ],
      "amount_billing": {},
      "amount_converted": {},
      "amount_fee": {},
      "amount_local": {},
      "amount_original_billing": {},
      "amount_original_local": {},
      "applied_limit": "",
      "authorisation_status": "",
      "authorisation_type": "",
      "card_authorisation_id_response": "",
      "card_id": 0,
      "city": "",
      "clearing_expiry_time": "",
      "clearing_status": "",
      "counterparty_alias": {},
      "decision": "",
      "decision_description": "",
      "decision_description_translated": "",
      "decision_together_url": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "id": 0,
      "label_card": {},
      "maturity_date": "",
      "monetary_account_id": 0,
      "pan_entry_mode_user": "",
      "payment_status": "",
      "pos_card_holder_presence": "",
      "pos_card_presence": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "reservation_expiry_time": "",
      "secure_code_id": 0,
      "settlement_status": "",
      "token_status": "",
      "wallet_provider_id": ""
    },
    "Payment": {},
    "PaymentBatch": {},
    "RequestResponse": {
      "address_billing": {},
      "address_shipping": {},
      "alias": {},
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "content_type": "",
          "description": "",
          "urls": [
            {
              "type": "",
              "url": ""
            }
          ]
        }
      ],
      "counterparty_alias": {},
      "created": "",
      "credit_scheme_identifier": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "mandate_identifier": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "require_address": "",
      "status": "",
      "sub_type": "",
      "time_expiry": "",
      "time_refund_requested": "",
      "time_refunded": "",
      "time_responded": "",
      "type": "",
      "updated": "",
      "user_refund_requested": {}
    },
    "ScheduleInstance": {
      "error_message": [],
      "request_reference_split_the_bill": [
        {}
      ],
      "result_object": {
        "Payment": {},
        "PaymentBatch": {}
      },
      "scheduled_object": {},
      "state": "",
      "time_end": "",
      "time_start": ""
    },
    "TransferwisePayment": {
      "alias": {},
      "amount_source": {},
      "amount_target": {},
      "counterparty_alias": {},
      "monetary_account_id": "",
      "pay_in_reference": "",
      "quote": {
        "amount_fee": {},
        "amount_source": {},
        "amount_target": {},
        "created": "",
        "currency_source": "",
        "currency_target": "",
        "id": 0,
        "quote_id": "",
        "rate": "",
        "time_delivery_estimate": "",
        "time_expiry": "",
        "updated": ""
      },
      "rate": "",
      "recipient_id": "",
      "reference": "",
      "status": "",
      "status_transferwise": "",
      "status_transferwise_issue": "",
      "sub_status": "",
      "time_delivery_estimate": ""
    },
    "WhitelistResult": {
      "error_message": [],
      "id": 0,
      "monetary_account_paying_id": 0,
      "object": {
        "draftPayment": {},
        "id": 0,
        "requestResponse": {}
      },
      "request_reference_split_the_bill": [
        {}
      ],
      "status": "",
      "sub_status": "",
      "whitelist": {}
    }
  },
  "request_inquiries": [
    {
      "address_billing": {},
      "address_shipping": {},
      "allow_amount_higher": false,
      "allow_amount_lower": false,
      "allow_bunqme": false,
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "id": 0
        }
      ],
      "batch_id": 0,
      "bunqme_share_url": "",
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "merchant_reference": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "reference_split_the_bill": {},
      "require_address": "",
      "scheduled_id": 0,
      "status": "",
      "time_expiry": "",
      "time_responded": "",
      "updated": "",
      "user_alias_created": {},
      "user_alias_revoked": {},
      "want_tip": false
    }
  ],
  "status": "",
  "total_amount_inquired": {}
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"event_id\": 0,\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {\n                \"currency\": \"\",\n                \"value\": \"\"\n              },\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {\n              \"altitude\": 0,\n              \"latitude\": 0,\n              \"longitude\": 0,\n              \"radius\": 0\n            },\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"request_inquiries\": [\n    {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"allow_amount_higher\": false,\n      \"allow_amount_lower\": false,\n      \"allow_bunqme\": false,\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"id\": 0\n        }\n      ],\n      \"batch_id\": 0,\n      \"bunqme_share_url\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"reference_split_the_bill\": {},\n      \"require_address\": \"\",\n      \"scheduled_id\": 0,\n      \"status\": \"\",\n      \"time_expiry\": \"\",\n      \"time_responded\": \"\",\n      \"updated\": \"\",\n      \"user_alias_created\": {},\n      \"user_alias_revoked\": {},\n      \"want_tip\": false\n    }\n  ],\n  \"status\": \"\",\n  \"total_amount_inquired\": {}\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId" {:headers {:user-agent ""
                                                                                                                                     :x-bunq-client-authentication ""}
                                                                                                                           :content-type :json
                                                                                                                           :form-params {:event_id 0
                                                                                                                                         :reference_split_the_bill {:BillingInvoice {:address {:city ""
                                                                                                                                                                                               :country ""
                                                                                                                                                                                               :extra ""
                                                                                                                                                                                               :house_number ""
                                                                                                                                                                                               :is_user_address_updated false
                                                                                                                                                                                               :mailbox_name ""
                                                                                                                                                                                               :po_box ""
                                                                                                                                                                                               :postal_code ""
                                                                                                                                                                                               :province ""
                                                                                                                                                                                               :street ""}
                                                                                                                                                                                     :alias {:avatar {:anchor_uuid ""
                                                                                                                                                                                                      :image [{:attachment_public_uuid ""
                                                                                                                                                                                                               :content_type ""
                                                                                                                                                                                                               :height 0
                                                                                                                                                                                                               :width 0}]
                                                                                                                                                                                                      :style ""
                                                                                                                                                                                                      :uuid ""}
                                                                                                                                                                                             :bunq_me {:name ""
                                                                                                                                                                                                       :service ""
                                                                                                                                                                                                       :type ""
                                                                                                                                                                                                       :value ""}
                                                                                                                                                                                             :country ""
                                                                                                                                                                                             :display_name ""
                                                                                                                                                                                             :iban ""
                                                                                                                                                                                             :is_light false
                                                                                                                                                                                             :label_user {:avatar {}
                                                                                                                                                                                                          :country ""
                                                                                                                                                                                                          :display_name ""
                                                                                                                                                                                                          :public_nick_name ""
                                                                                                                                                                                                          :uuid ""}
                                                                                                                                                                                             :merchant_category_code ""
                                                                                                                                                                                             :swift_account_number ""
                                                                                                                                                                                             :swift_bic ""
                                                                                                                                                                                             :transferwise_account_number ""
                                                                                                                                                                                             :transferwise_bank_code ""}
                                                                                                                                                                                     :category ""
                                                                                                                                                                                     :chamber_of_commerce_number ""
                                                                                                                                                                                     :counterparty_address {}
                                                                                                                                                                                     :counterparty_alias {}
                                                                                                                                                                                     :created ""
                                                                                                                                                                                     :description ""
                                                                                                                                                                                     :external_url ""
                                                                                                                                                                                     :group [{:instance_description ""
                                                                                                                                                                                              :item [{:billing_date ""
                                                                                                                                                                                                      :id 0
                                                                                                                                                                                                      :quantity 0
                                                                                                                                                                                                      :total_vat_exclusive {:currency ""
                                                                                                                                                                                                                            :value ""}
                                                                                                                                                                                                      :total_vat_inclusive {}
                                                                                                                                                                                                      :type_description ""
                                                                                                                                                                                                      :type_description_translated ""
                                                                                                                                                                                                      :unit_vat_exclusive {}
                                                                                                                                                                                                      :unit_vat_inclusive {}
                                                                                                                                                                                                      :vat 0}]
                                                                                                                                                                                              :product_vat_exclusive {}
                                                                                                                                                                                              :product_vat_inclusive {}
                                                                                                                                                                                              :type ""
                                                                                                                                                                                              :type_description ""
                                                                                                                                                                                              :type_description_translated ""}]
                                                                                                                                                                                     :id 0
                                                                                                                                                                                     :invoice_date ""
                                                                                                                                                                                     :invoice_number ""
                                                                                                                                                                                     :request_reference_split_the_bill [{:id 0
                                                                                                                                                                                                                         :type ""}]
                                                                                                                                                                                     :status ""
                                                                                                                                                                                     :total_vat {}
                                                                                                                                                                                     :total_vat_exclusive {}
                                                                                                                                                                                     :total_vat_inclusive {}
                                                                                                                                                                                     :updated ""
                                                                                                                                                                                     :vat_number ""}
                                                                                                                                                                    :DraftPayment {:entries [{:alias {}
                                                                                                                                                                                              :amount {}
                                                                                                                                                                                              :attachment [{:id 0
                                                                                                                                                                                                            :monetary_account_id 0}]
                                                                                                                                                                                              :counterparty_alias {}
                                                                                                                                                                                              :description ""
                                                                                                                                                                                              :id 0
                                                                                                                                                                                              :merchant_reference ""
                                                                                                                                                                                              :type ""}]
                                                                                                                                                                                   :number_of_required_accepts 0
                                                                                                                                                                                   :previous_updated_timestamp ""
                                                                                                                                                                                   :schedule {:object {:Payment {:address_billing {}
                                                                                                                                                                                                                 :address_shipping {}
                                                                                                                                                                                                                 :alias {}
                                                                                                                                                                                                                 :allow_bunqto false
                                                                                                                                                                                                                 :amount {}
                                                                                                                                                                                                                 :attachment [{}]
                                                                                                                                                                                                                 :balance_after_mutation {}
                                                                                                                                                                                                                 :batch_id 0
                                                                                                                                                                                                                 :bunqto_expiry ""
                                                                                                                                                                                                                 :bunqto_share_url ""
                                                                                                                                                                                                                 :bunqto_status ""
                                                                                                                                                                                                                 :bunqto_sub_status ""
                                                                                                                                                                                                                 :bunqto_time_responded ""
                                                                                                                                                                                                                 :counterparty_alias {}
                                                                                                                                                                                                                 :created ""
                                                                                                                                                                                                                 :description ""
                                                                                                                                                                                                                 :geolocation {:altitude 0
                                                                                                                                                                                                                               :latitude 0
                                                                                                                                                                                                                               :longitude 0
                                                                                                                                                                                                                               :radius 0}
                                                                                                                                                                                                                 :id 0
                                                                                                                                                                                                                 :merchant_reference ""
                                                                                                                                                                                                                 :monetary_account_id 0
                                                                                                                                                                                                                 :payment_auto_allocate_instance {:created ""
                                                                                                                                                                                                                                                  :error_message []
                                                                                                                                                                                                                                                  :id 0
                                                                                                                                                                                                                                                  :payment_auto_allocate_id 0
                                                                                                                                                                                                                                                  :payment_batch {:payments {:Payment []}}
                                                                                                                                                                                                                                                  :payment_id 0
                                                                                                                                                                                                                                                  :status ""
                                                                                                                                                                                                                                                  :updated ""}
                                                                                                                                                                                                                 :request_reference_split_the_bill [{}]
                                                                                                                                                                                                                 :scheduled_id 0
                                                                                                                                                                                                                 :sub_type ""
                                                                                                                                                                                                                 :type ""
                                                                                                                                                                                                                 :updated ""}
                                                                                                                                                                                                       :PaymentBatch {}}
                                                                                                                                                                                              :recurrence_size 0
                                                                                                                                                                                              :recurrence_unit ""
                                                                                                                                                                                              :status ""
                                                                                                                                                                                              :time_end ""
                                                                                                                                                                                              :time_start ""}
                                                                                                                                                                                   :status ""}
                                                                                                                                                                    :MasterCardAction {:alias {}
                                                                                                                                                                                       :all_mastercard_action_refund [{:additional_information {:attachment [{:id 0}]
                                                                                                                                                                                                                                                :category ""
                                                                                                                                                                                                                                                :comment ""
                                                                                                                                                                                                                                                :reason ""
                                                                                                                                                                                                                                                :terms_and_conditions ""}
                                                                                                                                                                                                                       :alias {}
                                                                                                                                                                                                                       :amount {}
                                                                                                                                                                                                                       :attachment [{}]
                                                                                                                                                                                                                       :category ""
                                                                                                                                                                                                                       :comment ""
                                                                                                                                                                                                                       :counterparty_alias {}
                                                                                                                                                                                                                       :created ""
                                                                                                                                                                                                                       :description ""
                                                                                                                                                                                                                       :id 0
                                                                                                                                                                                                                       :label_card {:expiry_date ""
                                                                                                                                                                                                                                    :label_user {}
                                                                                                                                                                                                                                    :second_line ""
                                                                                                                                                                                                                                    :status ""
                                                                                                                                                                                                                                    :type ""
                                                                                                                                                                                                                                    :uuid ""}
                                                                                                                                                                                                                       :label_user_creator {}
                                                                                                                                                                                                                       :mastercard_action_id 0
                                                                                                                                                                                                                       :reason ""
                                                                                                                                                                                                                       :reference_mastercard_action_event [{:event_id 0}]
                                                                                                                                                                                                                       :status ""
                                                                                                                                                                                                                       :status_description ""
                                                                                                                                                                                                                       :status_description_translated ""
                                                                                                                                                                                                                       :status_together_url ""
                                                                                                                                                                                                                       :sub_type ""
                                                                                                                                                                                                                       :terms_and_conditions ""
                                                                                                                                                                                                                       :time_refund ""
                                                                                                                                                                                                                       :type ""
                                                                                                                                                                                                                       :updated ""}]
                                                                                                                                                                                       :amount_billing {}
                                                                                                                                                                                       :amount_converted {}
                                                                                                                                                                                       :amount_fee {}
                                                                                                                                                                                       :amount_local {}
                                                                                                                                                                                       :amount_original_billing {}
                                                                                                                                                                                       :amount_original_local {}
                                                                                                                                                                                       :applied_limit ""
                                                                                                                                                                                       :authorisation_status ""
                                                                                                                                                                                       :authorisation_type ""
                                                                                                                                                                                       :card_authorisation_id_response ""
                                                                                                                                                                                       :card_id 0
                                                                                                                                                                                       :city ""
                                                                                                                                                                                       :clearing_expiry_time ""
                                                                                                                                                                                       :clearing_status ""
                                                                                                                                                                                       :counterparty_alias {}
                                                                                                                                                                                       :decision ""
                                                                                                                                                                                       :decision_description ""
                                                                                                                                                                                       :decision_description_translated ""
                                                                                                                                                                                       :decision_together_url ""
                                                                                                                                                                                       :description ""
                                                                                                                                                                                       :eligible_whitelist_id 0
                                                                                                                                                                                       :id 0
                                                                                                                                                                                       :label_card {}
                                                                                                                                                                                       :maturity_date ""
                                                                                                                                                                                       :monetary_account_id 0
                                                                                                                                                                                       :pan_entry_mode_user ""
                                                                                                                                                                                       :payment_status ""
                                                                                                                                                                                       :pos_card_holder_presence ""
                                                                                                                                                                                       :pos_card_presence ""
                                                                                                                                                                                       :request_reference_split_the_bill [{}]
                                                                                                                                                                                       :reservation_expiry_time ""
                                                                                                                                                                                       :secure_code_id 0
                                                                                                                                                                                       :settlement_status ""
                                                                                                                                                                                       :token_status ""
                                                                                                                                                                                       :wallet_provider_id ""}
                                                                                                                                                                    :Payment {}
                                                                                                                                                                    :PaymentBatch {}
                                                                                                                                                                    :RequestResponse {:address_billing {}
                                                                                                                                                                                      :address_shipping {}
                                                                                                                                                                                      :alias {}
                                                                                                                                                                                      :amount_inquired {}
                                                                                                                                                                                      :amount_responded {}
                                                                                                                                                                                      :attachment [{:content_type ""
                                                                                                                                                                                                    :description ""
                                                                                                                                                                                                    :urls [{:type ""
                                                                                                                                                                                                            :url ""}]}]
                                                                                                                                                                                      :counterparty_alias {}
                                                                                                                                                                                      :created ""
                                                                                                                                                                                      :credit_scheme_identifier ""
                                                                                                                                                                                      :description ""
                                                                                                                                                                                      :eligible_whitelist_id 0
                                                                                                                                                                                      :event_id 0
                                                                                                                                                                                      :geolocation {}
                                                                                                                                                                                      :id 0
                                                                                                                                                                                      :mandate_identifier ""
                                                                                                                                                                                      :minimum_age 0
                                                                                                                                                                                      :monetary_account_id 0
                                                                                                                                                                                      :redirect_url ""
                                                                                                                                                                                      :request_reference_split_the_bill [{}]
                                                                                                                                                                                      :require_address ""
                                                                                                                                                                                      :status ""
                                                                                                                                                                                      :sub_type ""
                                                                                                                                                                                      :time_expiry ""
                                                                                                                                                                                      :time_refund_requested ""
                                                                                                                                                                                      :time_refunded ""
                                                                                                                                                                                      :time_responded ""
                                                                                                                                                                                      :type ""
                                                                                                                                                                                      :updated ""
                                                                                                                                                                                      :user_refund_requested {}}
                                                                                                                                                                    :ScheduleInstance {:error_message []
                                                                                                                                                                                       :request_reference_split_the_bill [{}]
                                                                                                                                                                                       :result_object {:Payment {}
                                                                                                                                                                                                       :PaymentBatch {}}
                                                                                                                                                                                       :scheduled_object {}
                                                                                                                                                                                       :state ""
                                                                                                                                                                                       :time_end ""
                                                                                                                                                                                       :time_start ""}
                                                                                                                                                                    :TransferwisePayment {:alias {}
                                                                                                                                                                                          :amount_source {}
                                                                                                                                                                                          :amount_target {}
                                                                                                                                                                                          :counterparty_alias {}
                                                                                                                                                                                          :monetary_account_id ""
                                                                                                                                                                                          :pay_in_reference ""
                                                                                                                                                                                          :quote {:amount_fee {}
                                                                                                                                                                                                  :amount_source {}
                                                                                                                                                                                                  :amount_target {}
                                                                                                                                                                                                  :created ""
                                                                                                                                                                                                  :currency_source ""
                                                                                                                                                                                                  :currency_target ""
                                                                                                                                                                                                  :id 0
                                                                                                                                                                                                  :quote_id ""
                                                                                                                                                                                                  :rate ""
                                                                                                                                                                                                  :time_delivery_estimate ""
                                                                                                                                                                                                  :time_expiry ""
                                                                                                                                                                                                  :updated ""}
                                                                                                                                                                                          :rate ""
                                                                                                                                                                                          :recipient_id ""
                                                                                                                                                                                          :reference ""
                                                                                                                                                                                          :status ""
                                                                                                                                                                                          :status_transferwise ""
                                                                                                                                                                                          :status_transferwise_issue ""
                                                                                                                                                                                          :sub_status ""
                                                                                                                                                                                          :time_delivery_estimate ""}
                                                                                                                                                                    :WhitelistResult {:error_message []
                                                                                                                                                                                      :id 0
                                                                                                                                                                                      :monetary_account_paying_id 0
                                                                                                                                                                                      :object {:draftPayment {}
                                                                                                                                                                                               :id 0
                                                                                                                                                                                               :requestResponse {}}
                                                                                                                                                                                      :request_reference_split_the_bill [{}]
                                                                                                                                                                                      :status ""
                                                                                                                                                                                      :sub_status ""
                                                                                                                                                                                      :whitelist {}}}
                                                                                                                                         :request_inquiries [{:address_billing {}
                                                                                                                                                              :address_shipping {}
                                                                                                                                                              :allow_amount_higher false
                                                                                                                                                              :allow_amount_lower false
                                                                                                                                                              :allow_bunqme false
                                                                                                                                                              :amount_inquired {}
                                                                                                                                                              :amount_responded {}
                                                                                                                                                              :attachment [{:id 0}]
                                                                                                                                                              :batch_id 0
                                                                                                                                                              :bunqme_share_url ""
                                                                                                                                                              :counterparty_alias {}
                                                                                                                                                              :created ""
                                                                                                                                                              :description ""
                                                                                                                                                              :event_id 0
                                                                                                                                                              :geolocation {}
                                                                                                                                                              :id 0
                                                                                                                                                              :merchant_reference ""
                                                                                                                                                              :minimum_age 0
                                                                                                                                                              :monetary_account_id 0
                                                                                                                                                              :redirect_url ""
                                                                                                                                                              :reference_split_the_bill {}
                                                                                                                                                              :require_address ""
                                                                                                                                                              :scheduled_id 0
                                                                                                                                                              :status ""
                                                                                                                                                              :time_expiry ""
                                                                                                                                                              :time_responded ""
                                                                                                                                                              :updated ""
                                                                                                                                                              :user_alias_created {}
                                                                                                                                                              :user_alias_revoked {}
                                                                                                                                                              :want_tip false}]
                                                                                                                                         :status ""
                                                                                                                                         :total_amount_inquired {}}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"event_id\": 0,\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {\n                \"currency\": \"\",\n                \"value\": \"\"\n              },\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {\n              \"altitude\": 0,\n              \"latitude\": 0,\n              \"longitude\": 0,\n              \"radius\": 0\n            },\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"request_inquiries\": [\n    {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"allow_amount_higher\": false,\n      \"allow_amount_lower\": false,\n      \"allow_bunqme\": false,\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"id\": 0\n        }\n      ],\n      \"batch_id\": 0,\n      \"bunqme_share_url\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"reference_split_the_bill\": {},\n      \"require_address\": \"\",\n      \"scheduled_id\": 0,\n      \"status\": \"\",\n      \"time_expiry\": \"\",\n      \"time_responded\": \"\",\n      \"updated\": \"\",\n      \"user_alias_created\": {},\n      \"user_alias_revoked\": {},\n      \"want_tip\": false\n    }\n  ],\n  \"status\": \"\",\n  \"total_amount_inquired\": {}\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"event_id\": 0,\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {\n                \"currency\": \"\",\n                \"value\": \"\"\n              },\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {\n              \"altitude\": 0,\n              \"latitude\": 0,\n              \"longitude\": 0,\n              \"radius\": 0\n            },\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"request_inquiries\": [\n    {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"allow_amount_higher\": false,\n      \"allow_amount_lower\": false,\n      \"allow_bunqme\": false,\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"id\": 0\n        }\n      ],\n      \"batch_id\": 0,\n      \"bunqme_share_url\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"reference_split_the_bill\": {},\n      \"require_address\": \"\",\n      \"scheduled_id\": 0,\n      \"status\": \"\",\n      \"time_expiry\": \"\",\n      \"time_responded\": \"\",\n      \"updated\": \"\",\n      \"user_alias_created\": {},\n      \"user_alias_revoked\": {},\n      \"want_tip\": false\n    }\n  ],\n  \"status\": \"\",\n  \"total_amount_inquired\": {}\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"event_id\": 0,\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {\n                \"currency\": \"\",\n                \"value\": \"\"\n              },\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {\n              \"altitude\": 0,\n              \"latitude\": 0,\n              \"longitude\": 0,\n              \"radius\": 0\n            },\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"request_inquiries\": [\n    {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"allow_amount_higher\": false,\n      \"allow_amount_lower\": false,\n      \"allow_bunqme\": false,\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"id\": 0\n        }\n      ],\n      \"batch_id\": 0,\n      \"bunqme_share_url\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"reference_split_the_bill\": {},\n      \"require_address\": \"\",\n      \"scheduled_id\": 0,\n      \"status\": \"\",\n      \"time_expiry\": \"\",\n      \"time_responded\": \"\",\n      \"updated\": \"\",\n      \"user_alias_created\": {},\n      \"user_alias_revoked\": {},\n      \"want_tip\": false\n    }\n  ],\n  \"status\": \"\",\n  \"total_amount_inquired\": {}\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId"

	payload := strings.NewReader("{\n  \"event_id\": 0,\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {\n                \"currency\": \"\",\n                \"value\": \"\"\n              },\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {\n              \"altitude\": 0,\n              \"latitude\": 0,\n              \"longitude\": 0,\n              \"radius\": 0\n            },\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"request_inquiries\": [\n    {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"allow_amount_higher\": false,\n      \"allow_amount_lower\": false,\n      \"allow_bunqme\": false,\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"id\": 0\n        }\n      ],\n      \"batch_id\": 0,\n      \"bunqme_share_url\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"reference_split_the_bill\": {},\n      \"require_address\": \"\",\n      \"scheduled_id\": 0,\n      \"status\": \"\",\n      \"time_expiry\": \"\",\n      \"time_responded\": \"\",\n      \"updated\": \"\",\n      \"user_alias_created\": {},\n      \"user_alias_revoked\": {},\n      \"want_tip\": false\n    }\n  ],\n  \"status\": \"\",\n  \"total_amount_inquired\": {}\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 10610

{
  "event_id": 0,
  "reference_split_the_bill": {
    "BillingInvoice": {
      "address": {
        "city": "",
        "country": "",
        "extra": "",
        "house_number": "",
        "is_user_address_updated": false,
        "mailbox_name": "",
        "po_box": "",
        "postal_code": "",
        "province": "",
        "street": ""
      },
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "category": "",
      "chamber_of_commerce_number": "",
      "counterparty_address": {},
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "external_url": "",
      "group": [
        {
          "instance_description": "",
          "item": [
            {
              "billing_date": "",
              "id": 0,
              "quantity": 0,
              "total_vat_exclusive": {
                "currency": "",
                "value": ""
              },
              "total_vat_inclusive": {},
              "type_description": "",
              "type_description_translated": "",
              "unit_vat_exclusive": {},
              "unit_vat_inclusive": {},
              "vat": 0
            }
          ],
          "product_vat_exclusive": {},
          "product_vat_inclusive": {},
          "type": "",
          "type_description": "",
          "type_description_translated": ""
        }
      ],
      "id": 0,
      "invoice_date": "",
      "invoice_number": "",
      "request_reference_split_the_bill": [
        {
          "id": 0,
          "type": ""
        }
      ],
      "status": "",
      "total_vat": {},
      "total_vat_exclusive": {},
      "total_vat_inclusive": {},
      "updated": "",
      "vat_number": ""
    },
    "DraftPayment": {
      "entries": [
        {
          "alias": {},
          "amount": {},
          "attachment": [
            {
              "id": 0,
              "monetary_account_id": 0
            }
          ],
          "counterparty_alias": {},
          "description": "",
          "id": 0,
          "merchant_reference": "",
          "type": ""
        }
      ],
      "number_of_required_accepts": 0,
      "previous_updated_timestamp": "",
      "schedule": {
        "object": {
          "Payment": {
            "address_billing": {},
            "address_shipping": {},
            "alias": {},
            "allow_bunqto": false,
            "amount": {},
            "attachment": [
              {}
            ],
            "balance_after_mutation": {},
            "batch_id": 0,
            "bunqto_expiry": "",
            "bunqto_share_url": "",
            "bunqto_status": "",
            "bunqto_sub_status": "",
            "bunqto_time_responded": "",
            "counterparty_alias": {},
            "created": "",
            "description": "",
            "geolocation": {
              "altitude": 0,
              "latitude": 0,
              "longitude": 0,
              "radius": 0
            },
            "id": 0,
            "merchant_reference": "",
            "monetary_account_id": 0,
            "payment_auto_allocate_instance": {
              "created": "",
              "error_message": [],
              "id": 0,
              "payment_auto_allocate_id": 0,
              "payment_batch": {
                "payments": {
                  "Payment": []
                }
              },
              "payment_id": 0,
              "status": "",
              "updated": ""
            },
            "request_reference_split_the_bill": [
              {}
            ],
            "scheduled_id": 0,
            "sub_type": "",
            "type": "",
            "updated": ""
          },
          "PaymentBatch": {}
        },
        "recurrence_size": 0,
        "recurrence_unit": "",
        "status": "",
        "time_end": "",
        "time_start": ""
      },
      "status": ""
    },
    "MasterCardAction": {
      "alias": {},
      "all_mastercard_action_refund": [
        {
          "additional_information": {
            "attachment": [
              {
                "id": 0
              }
            ],
            "category": "",
            "comment": "",
            "reason": "",
            "terms_and_conditions": ""
          },
          "alias": {},
          "amount": {},
          "attachment": [
            {}
          ],
          "category": "",
          "comment": "",
          "counterparty_alias": {},
          "created": "",
          "description": "",
          "id": 0,
          "label_card": {
            "expiry_date": "",
            "label_user": {},
            "second_line": "",
            "status": "",
            "type": "",
            "uuid": ""
          },
          "label_user_creator": {},
          "mastercard_action_id": 0,
          "reason": "",
          "reference_mastercard_action_event": [
            {
              "event_id": 0
            }
          ],
          "status": "",
          "status_description": "",
          "status_description_translated": "",
          "status_together_url": "",
          "sub_type": "",
          "terms_and_conditions": "",
          "time_refund": "",
          "type": "",
          "updated": ""
        }
      ],
      "amount_billing": {},
      "amount_converted": {},
      "amount_fee": {},
      "amount_local": {},
      "amount_original_billing": {},
      "amount_original_local": {},
      "applied_limit": "",
      "authorisation_status": "",
      "authorisation_type": "",
      "card_authorisation_id_response": "",
      "card_id": 0,
      "city": "",
      "clearing_expiry_time": "",
      "clearing_status": "",
      "counterparty_alias": {},
      "decision": "",
      "decision_description": "",
      "decision_description_translated": "",
      "decision_together_url": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "id": 0,
      "label_card": {},
      "maturity_date": "",
      "monetary_account_id": 0,
      "pan_entry_mode_user": "",
      "payment_status": "",
      "pos_card_holder_presence": "",
      "pos_card_presence": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "reservation_expiry_time": "",
      "secure_code_id": 0,
      "settlement_status": "",
      "token_status": "",
      "wallet_provider_id": ""
    },
    "Payment": {},
    "PaymentBatch": {},
    "RequestResponse": {
      "address_billing": {},
      "address_shipping": {},
      "alias": {},
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "content_type": "",
          "description": "",
          "urls": [
            {
              "type": "",
              "url": ""
            }
          ]
        }
      ],
      "counterparty_alias": {},
      "created": "",
      "credit_scheme_identifier": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "mandate_identifier": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "require_address": "",
      "status": "",
      "sub_type": "",
      "time_expiry": "",
      "time_refund_requested": "",
      "time_refunded": "",
      "time_responded": "",
      "type": "",
      "updated": "",
      "user_refund_requested": {}
    },
    "ScheduleInstance": {
      "error_message": [],
      "request_reference_split_the_bill": [
        {}
      ],
      "result_object": {
        "Payment": {},
        "PaymentBatch": {}
      },
      "scheduled_object": {},
      "state": "",
      "time_end": "",
      "time_start": ""
    },
    "TransferwisePayment": {
      "alias": {},
      "amount_source": {},
      "amount_target": {},
      "counterparty_alias": {},
      "monetary_account_id": "",
      "pay_in_reference": "",
      "quote": {
        "amount_fee": {},
        "amount_source": {},
        "amount_target": {},
        "created": "",
        "currency_source": "",
        "currency_target": "",
        "id": 0,
        "quote_id": "",
        "rate": "",
        "time_delivery_estimate": "",
        "time_expiry": "",
        "updated": ""
      },
      "rate": "",
      "recipient_id": "",
      "reference": "",
      "status": "",
      "status_transferwise": "",
      "status_transferwise_issue": "",
      "sub_status": "",
      "time_delivery_estimate": ""
    },
    "WhitelistResult": {
      "error_message": [],
      "id": 0,
      "monetary_account_paying_id": 0,
      "object": {
        "draftPayment": {},
        "id": 0,
        "requestResponse": {}
      },
      "request_reference_split_the_bill": [
        {}
      ],
      "status": "",
      "sub_status": "",
      "whitelist": {}
    }
  },
  "request_inquiries": [
    {
      "address_billing": {},
      "address_shipping": {},
      "allow_amount_higher": false,
      "allow_amount_lower": false,
      "allow_bunqme": false,
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "id": 0
        }
      ],
      "batch_id": 0,
      "bunqme_share_url": "",
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "merchant_reference": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "reference_split_the_bill": {},
      "require_address": "",
      "scheduled_id": 0,
      "status": "",
      "time_expiry": "",
      "time_responded": "",
      "updated": "",
      "user_alias_created": {},
      "user_alias_revoked": {},
      "want_tip": false
    }
  ],
  "status": "",
  "total_amount_inquired": {}
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"event_id\": 0,\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {\n                \"currency\": \"\",\n                \"value\": \"\"\n              },\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {\n              \"altitude\": 0,\n              \"latitude\": 0,\n              \"longitude\": 0,\n              \"radius\": 0\n            },\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"request_inquiries\": [\n    {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"allow_amount_higher\": false,\n      \"allow_amount_lower\": false,\n      \"allow_bunqme\": false,\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"id\": 0\n        }\n      ],\n      \"batch_id\": 0,\n      \"bunqme_share_url\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"reference_split_the_bill\": {},\n      \"require_address\": \"\",\n      \"scheduled_id\": 0,\n      \"status\": \"\",\n      \"time_expiry\": \"\",\n      \"time_responded\": \"\",\n      \"updated\": \"\",\n      \"user_alias_created\": {},\n      \"user_alias_revoked\": {},\n      \"want_tip\": false\n    }\n  ],\n  \"status\": \"\",\n  \"total_amount_inquired\": {}\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"event_id\": 0,\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {\n                \"currency\": \"\",\n                \"value\": \"\"\n              },\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {\n              \"altitude\": 0,\n              \"latitude\": 0,\n              \"longitude\": 0,\n              \"radius\": 0\n            },\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"request_inquiries\": [\n    {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"allow_amount_higher\": false,\n      \"allow_amount_lower\": false,\n      \"allow_bunqme\": false,\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"id\": 0\n        }\n      ],\n      \"batch_id\": 0,\n      \"bunqme_share_url\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"reference_split_the_bill\": {},\n      \"require_address\": \"\",\n      \"scheduled_id\": 0,\n      \"status\": \"\",\n      \"time_expiry\": \"\",\n      \"time_responded\": \"\",\n      \"updated\": \"\",\n      \"user_alias_created\": {},\n      \"user_alias_revoked\": {},\n      \"want_tip\": false\n    }\n  ],\n  \"status\": \"\",\n  \"total_amount_inquired\": {}\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"event_id\": 0,\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {\n                \"currency\": \"\",\n                \"value\": \"\"\n              },\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {\n              \"altitude\": 0,\n              \"latitude\": 0,\n              \"longitude\": 0,\n              \"radius\": 0\n            },\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"request_inquiries\": [\n    {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"allow_amount_higher\": false,\n      \"allow_amount_lower\": false,\n      \"allow_bunqme\": false,\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"id\": 0\n        }\n      ],\n      \"batch_id\": 0,\n      \"bunqme_share_url\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"reference_split_the_bill\": {},\n      \"require_address\": \"\",\n      \"scheduled_id\": 0,\n      \"status\": \"\",\n      \"time_expiry\": \"\",\n      \"time_responded\": \"\",\n      \"updated\": \"\",\n      \"user_alias_created\": {},\n      \"user_alias_revoked\": {},\n      \"want_tip\": false\n    }\n  ],\n  \"status\": \"\",\n  \"total_amount_inquired\": {}\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"event_id\": 0,\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {\n                \"currency\": \"\",\n                \"value\": \"\"\n              },\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {\n              \"altitude\": 0,\n              \"latitude\": 0,\n              \"longitude\": 0,\n              \"radius\": 0\n            },\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"request_inquiries\": [\n    {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"allow_amount_higher\": false,\n      \"allow_amount_lower\": false,\n      \"allow_bunqme\": false,\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"id\": 0\n        }\n      ],\n      \"batch_id\": 0,\n      \"bunqme_share_url\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"reference_split_the_bill\": {},\n      \"require_address\": \"\",\n      \"scheduled_id\": 0,\n      \"status\": \"\",\n      \"time_expiry\": \"\",\n      \"time_responded\": \"\",\n      \"updated\": \"\",\n      \"user_alias_created\": {},\n      \"user_alias_revoked\": {},\n      \"want_tip\": false\n    }\n  ],\n  \"status\": \"\",\n  \"total_amount_inquired\": {}\n}")
  .asString();
const data = JSON.stringify({
  event_id: 0,
  reference_split_the_bill: {
    BillingInvoice: {
      address: {
        city: '',
        country: '',
        extra: '',
        house_number: '',
        is_user_address_updated: false,
        mailbox_name: '',
        po_box: '',
        postal_code: '',
        province: '',
        street: ''
      },
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [
            {
              attachment_public_uuid: '',
              content_type: '',
              height: 0,
              width: 0
            }
          ],
          style: '',
          uuid: ''
        },
        bunq_me: {
          name: '',
          service: '',
          type: '',
          value: ''
        },
        country: '',
        display_name: '',
        iban: '',
        is_light: false,
        label_user: {
          avatar: {},
          country: '',
          display_name: '',
          public_nick_name: '',
          uuid: ''
        },
        merchant_category_code: '',
        swift_account_number: '',
        swift_bic: '',
        transferwise_account_number: '',
        transferwise_bank_code: ''
      },
      category: '',
      chamber_of_commerce_number: '',
      counterparty_address: {},
      counterparty_alias: {},
      created: '',
      description: '',
      external_url: '',
      group: [
        {
          instance_description: '',
          item: [
            {
              billing_date: '',
              id: 0,
              quantity: 0,
              total_vat_exclusive: {
                currency: '',
                value: ''
              },
              total_vat_inclusive: {},
              type_description: '',
              type_description_translated: '',
              unit_vat_exclusive: {},
              unit_vat_inclusive: {},
              vat: 0
            }
          ],
          product_vat_exclusive: {},
          product_vat_inclusive: {},
          type: '',
          type_description: '',
          type_description_translated: ''
        }
      ],
      id: 0,
      invoice_date: '',
      invoice_number: '',
      request_reference_split_the_bill: [
        {
          id: 0,
          type: ''
        }
      ],
      status: '',
      total_vat: {},
      total_vat_exclusive: {},
      total_vat_inclusive: {},
      updated: '',
      vat_number: ''
    },
    DraftPayment: {
      entries: [
        {
          alias: {},
          amount: {},
          attachment: [
            {
              id: 0,
              monetary_account_id: 0
            }
          ],
          counterparty_alias: {},
          description: '',
          id: 0,
          merchant_reference: '',
          type: ''
        }
      ],
      number_of_required_accepts: 0,
      previous_updated_timestamp: '',
      schedule: {
        object: {
          Payment: {
            address_billing: {},
            address_shipping: {},
            alias: {},
            allow_bunqto: false,
            amount: {},
            attachment: [
              {}
            ],
            balance_after_mutation: {},
            batch_id: 0,
            bunqto_expiry: '',
            bunqto_share_url: '',
            bunqto_status: '',
            bunqto_sub_status: '',
            bunqto_time_responded: '',
            counterparty_alias: {},
            created: '',
            description: '',
            geolocation: {
              altitude: 0,
              latitude: 0,
              longitude: 0,
              radius: 0
            },
            id: 0,
            merchant_reference: '',
            monetary_account_id: 0,
            payment_auto_allocate_instance: {
              created: '',
              error_message: [],
              id: 0,
              payment_auto_allocate_id: 0,
              payment_batch: {
                payments: {
                  Payment: []
                }
              },
              payment_id: 0,
              status: '',
              updated: ''
            },
            request_reference_split_the_bill: [
              {}
            ],
            scheduled_id: 0,
            sub_type: '',
            type: '',
            updated: ''
          },
          PaymentBatch: {}
        },
        recurrence_size: 0,
        recurrence_unit: '',
        status: '',
        time_end: '',
        time_start: ''
      },
      status: ''
    },
    MasterCardAction: {
      alias: {},
      all_mastercard_action_refund: [
        {
          additional_information: {
            attachment: [
              {
                id: 0
              }
            ],
            category: '',
            comment: '',
            reason: '',
            terms_and_conditions: ''
          },
          alias: {},
          amount: {},
          attachment: [
            {}
          ],
          category: '',
          comment: '',
          counterparty_alias: {},
          created: '',
          description: '',
          id: 0,
          label_card: {
            expiry_date: '',
            label_user: {},
            second_line: '',
            status: '',
            type: '',
            uuid: ''
          },
          label_user_creator: {},
          mastercard_action_id: 0,
          reason: '',
          reference_mastercard_action_event: [
            {
              event_id: 0
            }
          ],
          status: '',
          status_description: '',
          status_description_translated: '',
          status_together_url: '',
          sub_type: '',
          terms_and_conditions: '',
          time_refund: '',
          type: '',
          updated: ''
        }
      ],
      amount_billing: {},
      amount_converted: {},
      amount_fee: {},
      amount_local: {},
      amount_original_billing: {},
      amount_original_local: {},
      applied_limit: '',
      authorisation_status: '',
      authorisation_type: '',
      card_authorisation_id_response: '',
      card_id: 0,
      city: '',
      clearing_expiry_time: '',
      clearing_status: '',
      counterparty_alias: {},
      decision: '',
      decision_description: '',
      decision_description_translated: '',
      decision_together_url: '',
      description: '',
      eligible_whitelist_id: 0,
      id: 0,
      label_card: {},
      maturity_date: '',
      monetary_account_id: 0,
      pan_entry_mode_user: '',
      payment_status: '',
      pos_card_holder_presence: '',
      pos_card_presence: '',
      request_reference_split_the_bill: [
        {}
      ],
      reservation_expiry_time: '',
      secure_code_id: 0,
      settlement_status: '',
      token_status: '',
      wallet_provider_id: ''
    },
    Payment: {},
    PaymentBatch: {},
    RequestResponse: {
      address_billing: {},
      address_shipping: {},
      alias: {},
      amount_inquired: {},
      amount_responded: {},
      attachment: [
        {
          content_type: '',
          description: '',
          urls: [
            {
              type: '',
              url: ''
            }
          ]
        }
      ],
      counterparty_alias: {},
      created: '',
      credit_scheme_identifier: '',
      description: '',
      eligible_whitelist_id: 0,
      event_id: 0,
      geolocation: {},
      id: 0,
      mandate_identifier: '',
      minimum_age: 0,
      monetary_account_id: 0,
      redirect_url: '',
      request_reference_split_the_bill: [
        {}
      ],
      require_address: '',
      status: '',
      sub_type: '',
      time_expiry: '',
      time_refund_requested: '',
      time_refunded: '',
      time_responded: '',
      type: '',
      updated: '',
      user_refund_requested: {}
    },
    ScheduleInstance: {
      error_message: [],
      request_reference_split_the_bill: [
        {}
      ],
      result_object: {
        Payment: {},
        PaymentBatch: {}
      },
      scheduled_object: {},
      state: '',
      time_end: '',
      time_start: ''
    },
    TransferwisePayment: {
      alias: {},
      amount_source: {},
      amount_target: {},
      counterparty_alias: {},
      monetary_account_id: '',
      pay_in_reference: '',
      quote: {
        amount_fee: {},
        amount_source: {},
        amount_target: {},
        created: '',
        currency_source: '',
        currency_target: '',
        id: 0,
        quote_id: '',
        rate: '',
        time_delivery_estimate: '',
        time_expiry: '',
        updated: ''
      },
      rate: '',
      recipient_id: '',
      reference: '',
      status: '',
      status_transferwise: '',
      status_transferwise_issue: '',
      sub_status: '',
      time_delivery_estimate: ''
    },
    WhitelistResult: {
      error_message: [],
      id: 0,
      monetary_account_paying_id: 0,
      object: {
        draftPayment: {},
        id: 0,
        requestResponse: {}
      },
      request_reference_split_the_bill: [
        {}
      ],
      status: '',
      sub_status: '',
      whitelist: {}
    }
  },
  request_inquiries: [
    {
      address_billing: {},
      address_shipping: {},
      allow_amount_higher: false,
      allow_amount_lower: false,
      allow_bunqme: false,
      amount_inquired: {},
      amount_responded: {},
      attachment: [
        {
          id: 0
        }
      ],
      batch_id: 0,
      bunqme_share_url: '',
      counterparty_alias: {},
      created: '',
      description: '',
      event_id: 0,
      geolocation: {},
      id: 0,
      merchant_reference: '',
      minimum_age: 0,
      monetary_account_id: 0,
      redirect_url: '',
      reference_split_the_bill: {},
      require_address: '',
      scheduled_id: 0,
      status: '',
      time_expiry: '',
      time_responded: '',
      updated: '',
      user_alias_created: {},
      user_alias_revoked: {},
      want_tip: false
    }
  ],
  status: '',
  total_amount_inquired: {}
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    event_id: 0,
    reference_split_the_bill: {
      BillingInvoice: {
        address: {
          city: '',
          country: '',
          extra: '',
          house_number: '',
          is_user_address_updated: false,
          mailbox_name: '',
          po_box: '',
          postal_code: '',
          province: '',
          street: ''
        },
        alias: {
          avatar: {
            anchor_uuid: '',
            image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
            style: '',
            uuid: ''
          },
          bunq_me: {name: '', service: '', type: '', value: ''},
          country: '',
          display_name: '',
          iban: '',
          is_light: false,
          label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
          merchant_category_code: '',
          swift_account_number: '',
          swift_bic: '',
          transferwise_account_number: '',
          transferwise_bank_code: ''
        },
        category: '',
        chamber_of_commerce_number: '',
        counterparty_address: {},
        counterparty_alias: {},
        created: '',
        description: '',
        external_url: '',
        group: [
          {
            instance_description: '',
            item: [
              {
                billing_date: '',
                id: 0,
                quantity: 0,
                total_vat_exclusive: {currency: '', value: ''},
                total_vat_inclusive: {},
                type_description: '',
                type_description_translated: '',
                unit_vat_exclusive: {},
                unit_vat_inclusive: {},
                vat: 0
              }
            ],
            product_vat_exclusive: {},
            product_vat_inclusive: {},
            type: '',
            type_description: '',
            type_description_translated: ''
          }
        ],
        id: 0,
        invoice_date: '',
        invoice_number: '',
        request_reference_split_the_bill: [{id: 0, type: ''}],
        status: '',
        total_vat: {},
        total_vat_exclusive: {},
        total_vat_inclusive: {},
        updated: '',
        vat_number: ''
      },
      DraftPayment: {
        entries: [
          {
            alias: {},
            amount: {},
            attachment: [{id: 0, monetary_account_id: 0}],
            counterparty_alias: {},
            description: '',
            id: 0,
            merchant_reference: '',
            type: ''
          }
        ],
        number_of_required_accepts: 0,
        previous_updated_timestamp: '',
        schedule: {
          object: {
            Payment: {
              address_billing: {},
              address_shipping: {},
              alias: {},
              allow_bunqto: false,
              amount: {},
              attachment: [{}],
              balance_after_mutation: {},
              batch_id: 0,
              bunqto_expiry: '',
              bunqto_share_url: '',
              bunqto_status: '',
              bunqto_sub_status: '',
              bunqto_time_responded: '',
              counterparty_alias: {},
              created: '',
              description: '',
              geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
              id: 0,
              merchant_reference: '',
              monetary_account_id: 0,
              payment_auto_allocate_instance: {
                created: '',
                error_message: [],
                id: 0,
                payment_auto_allocate_id: 0,
                payment_batch: {payments: {Payment: []}},
                payment_id: 0,
                status: '',
                updated: ''
              },
              request_reference_split_the_bill: [{}],
              scheduled_id: 0,
              sub_type: '',
              type: '',
              updated: ''
            },
            PaymentBatch: {}
          },
          recurrence_size: 0,
          recurrence_unit: '',
          status: '',
          time_end: '',
          time_start: ''
        },
        status: ''
      },
      MasterCardAction: {
        alias: {},
        all_mastercard_action_refund: [
          {
            additional_information: {
              attachment: [{id: 0}],
              category: '',
              comment: '',
              reason: '',
              terms_and_conditions: ''
            },
            alias: {},
            amount: {},
            attachment: [{}],
            category: '',
            comment: '',
            counterparty_alias: {},
            created: '',
            description: '',
            id: 0,
            label_card: {
              expiry_date: '',
              label_user: {},
              second_line: '',
              status: '',
              type: '',
              uuid: ''
            },
            label_user_creator: {},
            mastercard_action_id: 0,
            reason: '',
            reference_mastercard_action_event: [{event_id: 0}],
            status: '',
            status_description: '',
            status_description_translated: '',
            status_together_url: '',
            sub_type: '',
            terms_and_conditions: '',
            time_refund: '',
            type: '',
            updated: ''
          }
        ],
        amount_billing: {},
        amount_converted: {},
        amount_fee: {},
        amount_local: {},
        amount_original_billing: {},
        amount_original_local: {},
        applied_limit: '',
        authorisation_status: '',
        authorisation_type: '',
        card_authorisation_id_response: '',
        card_id: 0,
        city: '',
        clearing_expiry_time: '',
        clearing_status: '',
        counterparty_alias: {},
        decision: '',
        decision_description: '',
        decision_description_translated: '',
        decision_together_url: '',
        description: '',
        eligible_whitelist_id: 0,
        id: 0,
        label_card: {},
        maturity_date: '',
        monetary_account_id: 0,
        pan_entry_mode_user: '',
        payment_status: '',
        pos_card_holder_presence: '',
        pos_card_presence: '',
        request_reference_split_the_bill: [{}],
        reservation_expiry_time: '',
        secure_code_id: 0,
        settlement_status: '',
        token_status: '',
        wallet_provider_id: ''
      },
      Payment: {},
      PaymentBatch: {},
      RequestResponse: {
        address_billing: {},
        address_shipping: {},
        alias: {},
        amount_inquired: {},
        amount_responded: {},
        attachment: [{content_type: '', description: '', urls: [{type: '', url: ''}]}],
        counterparty_alias: {},
        created: '',
        credit_scheme_identifier: '',
        description: '',
        eligible_whitelist_id: 0,
        event_id: 0,
        geolocation: {},
        id: 0,
        mandate_identifier: '',
        minimum_age: 0,
        monetary_account_id: 0,
        redirect_url: '',
        request_reference_split_the_bill: [{}],
        require_address: '',
        status: '',
        sub_type: '',
        time_expiry: '',
        time_refund_requested: '',
        time_refunded: '',
        time_responded: '',
        type: '',
        updated: '',
        user_refund_requested: {}
      },
      ScheduleInstance: {
        error_message: [],
        request_reference_split_the_bill: [{}],
        result_object: {Payment: {}, PaymentBatch: {}},
        scheduled_object: {},
        state: '',
        time_end: '',
        time_start: ''
      },
      TransferwisePayment: {
        alias: {},
        amount_source: {},
        amount_target: {},
        counterparty_alias: {},
        monetary_account_id: '',
        pay_in_reference: '',
        quote: {
          amount_fee: {},
          amount_source: {},
          amount_target: {},
          created: '',
          currency_source: '',
          currency_target: '',
          id: 0,
          quote_id: '',
          rate: '',
          time_delivery_estimate: '',
          time_expiry: '',
          updated: ''
        },
        rate: '',
        recipient_id: '',
        reference: '',
        status: '',
        status_transferwise: '',
        status_transferwise_issue: '',
        sub_status: '',
        time_delivery_estimate: ''
      },
      WhitelistResult: {
        error_message: [],
        id: 0,
        monetary_account_paying_id: 0,
        object: {draftPayment: {}, id: 0, requestResponse: {}},
        request_reference_split_the_bill: [{}],
        status: '',
        sub_status: '',
        whitelist: {}
      }
    },
    request_inquiries: [
      {
        address_billing: {},
        address_shipping: {},
        allow_amount_higher: false,
        allow_amount_lower: false,
        allow_bunqme: false,
        amount_inquired: {},
        amount_responded: {},
        attachment: [{id: 0}],
        batch_id: 0,
        bunqme_share_url: '',
        counterparty_alias: {},
        created: '',
        description: '',
        event_id: 0,
        geolocation: {},
        id: 0,
        merchant_reference: '',
        minimum_age: 0,
        monetary_account_id: 0,
        redirect_url: '',
        reference_split_the_bill: {},
        require_address: '',
        scheduled_id: 0,
        status: '',
        time_expiry: '',
        time_responded: '',
        updated: '',
        user_alias_created: {},
        user_alias_revoked: {},
        want_tip: false
      }
    ],
    status: '',
    total_amount_inquired: {}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"event_id":0,"reference_split_the_bill":{"BillingInvoice":{"address":{"city":"","country":"","extra":"","house_number":"","is_user_address_updated":false,"mailbox_name":"","po_box":"","postal_code":"","province":"","street":""},"alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"category":"","chamber_of_commerce_number":"","counterparty_address":{},"counterparty_alias":{},"created":"","description":"","external_url":"","group":[{"instance_description":"","item":[{"billing_date":"","id":0,"quantity":0,"total_vat_exclusive":{"currency":"","value":""},"total_vat_inclusive":{},"type_description":"","type_description_translated":"","unit_vat_exclusive":{},"unit_vat_inclusive":{},"vat":0}],"product_vat_exclusive":{},"product_vat_inclusive":{},"type":"","type_description":"","type_description_translated":""}],"id":0,"invoice_date":"","invoice_number":"","request_reference_split_the_bill":[{"id":0,"type":""}],"status":"","total_vat":{},"total_vat_exclusive":{},"total_vat_inclusive":{},"updated":"","vat_number":""},"DraftPayment":{"entries":[{"alias":{},"amount":{},"attachment":[{"id":0,"monetary_account_id":0}],"counterparty_alias":{},"description":"","id":0,"merchant_reference":"","type":""}],"number_of_required_accepts":0,"previous_updated_timestamp":"","schedule":{"object":{"Payment":{"address_billing":{},"address_shipping":{},"alias":{},"allow_bunqto":false,"amount":{},"attachment":[{}],"balance_after_mutation":{},"batch_id":0,"bunqto_expiry":"","bunqto_share_url":"","bunqto_status":"","bunqto_sub_status":"","bunqto_time_responded":"","counterparty_alias":{},"created":"","description":"","geolocation":{"altitude":0,"latitude":0,"longitude":0,"radius":0},"id":0,"merchant_reference":"","monetary_account_id":0,"payment_auto_allocate_instance":{"created":"","error_message":[],"id":0,"payment_auto_allocate_id":0,"payment_batch":{"payments":{"Payment":[]}},"payment_id":0,"status":"","updated":""},"request_reference_split_the_bill":[{}],"scheduled_id":0,"sub_type":"","type":"","updated":""},"PaymentBatch":{}},"recurrence_size":0,"recurrence_unit":"","status":"","time_end":"","time_start":""},"status":""},"MasterCardAction":{"alias":{},"all_mastercard_action_refund":[{"additional_information":{"attachment":[{"id":0}],"category":"","comment":"","reason":"","terms_and_conditions":""},"alias":{},"amount":{},"attachment":[{}],"category":"","comment":"","counterparty_alias":{},"created":"","description":"","id":0,"label_card":{"expiry_date":"","label_user":{},"second_line":"","status":"","type":"","uuid":""},"label_user_creator":{},"mastercard_action_id":0,"reason":"","reference_mastercard_action_event":[{"event_id":0}],"status":"","status_description":"","status_description_translated":"","status_together_url":"","sub_type":"","terms_and_conditions":"","time_refund":"","type":"","updated":""}],"amount_billing":{},"amount_converted":{},"amount_fee":{},"amount_local":{},"amount_original_billing":{},"amount_original_local":{},"applied_limit":"","authorisation_status":"","authorisation_type":"","card_authorisation_id_response":"","card_id":0,"city":"","clearing_expiry_time":"","clearing_status":"","counterparty_alias":{},"decision":"","decision_description":"","decision_description_translated":"","decision_together_url":"","description":"","eligible_whitelist_id":0,"id":0,"label_card":{},"maturity_date":"","monetary_account_id":0,"pan_entry_mode_user":"","payment_status":"","pos_card_holder_presence":"","pos_card_presence":"","request_reference_split_the_bill":[{}],"reservation_expiry_time":"","secure_code_id":0,"settlement_status":"","token_status":"","wallet_provider_id":""},"Payment":{},"PaymentBatch":{},"RequestResponse":{"address_billing":{},"address_shipping":{},"alias":{},"amount_inquired":{},"amount_responded":{},"attachment":[{"content_type":"","description":"","urls":[{"type":"","url":""}]}],"counterparty_alias":{},"created":"","credit_scheme_identifier":"","description":"","eligible_whitelist_id":0,"event_id":0,"geolocation":{},"id":0,"mandate_identifier":"","minimum_age":0,"monetary_account_id":0,"redirect_url":"","request_reference_split_the_bill":[{}],"require_address":"","status":"","sub_type":"","time_expiry":"","time_refund_requested":"","time_refunded":"","time_responded":"","type":"","updated":"","user_refund_requested":{}},"ScheduleInstance":{"error_message":[],"request_reference_split_the_bill":[{}],"result_object":{"Payment":{},"PaymentBatch":{}},"scheduled_object":{},"state":"","time_end":"","time_start":""},"TransferwisePayment":{"alias":{},"amount_source":{},"amount_target":{},"counterparty_alias":{},"monetary_account_id":"","pay_in_reference":"","quote":{"amount_fee":{},"amount_source":{},"amount_target":{},"created":"","currency_source":"","currency_target":"","id":0,"quote_id":"","rate":"","time_delivery_estimate":"","time_expiry":"","updated":""},"rate":"","recipient_id":"","reference":"","status":"","status_transferwise":"","status_transferwise_issue":"","sub_status":"","time_delivery_estimate":""},"WhitelistResult":{"error_message":[],"id":0,"monetary_account_paying_id":0,"object":{"draftPayment":{},"id":0,"requestResponse":{}},"request_reference_split_the_bill":[{}],"status":"","sub_status":"","whitelist":{}}},"request_inquiries":[{"address_billing":{},"address_shipping":{},"allow_amount_higher":false,"allow_amount_lower":false,"allow_bunqme":false,"amount_inquired":{},"amount_responded":{},"attachment":[{"id":0}],"batch_id":0,"bunqme_share_url":"","counterparty_alias":{},"created":"","description":"","event_id":0,"geolocation":{},"id":0,"merchant_reference":"","minimum_age":0,"monetary_account_id":0,"redirect_url":"","reference_split_the_bill":{},"require_address":"","scheduled_id":0,"status":"","time_expiry":"","time_responded":"","updated":"","user_alias_created":{},"user_alias_revoked":{},"want_tip":false}],"status":"","total_amount_inquired":{}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "event_id": 0,\n  "reference_split_the_bill": {\n    "BillingInvoice": {\n      "address": {\n        "city": "",\n        "country": "",\n        "extra": "",\n        "house_number": "",\n        "is_user_address_updated": false,\n        "mailbox_name": "",\n        "po_box": "",\n        "postal_code": "",\n        "province": "",\n        "street": ""\n      },\n      "alias": {\n        "avatar": {\n          "anchor_uuid": "",\n          "image": [\n            {\n              "attachment_public_uuid": "",\n              "content_type": "",\n              "height": 0,\n              "width": 0\n            }\n          ],\n          "style": "",\n          "uuid": ""\n        },\n        "bunq_me": {\n          "name": "",\n          "service": "",\n          "type": "",\n          "value": ""\n        },\n        "country": "",\n        "display_name": "",\n        "iban": "",\n        "is_light": false,\n        "label_user": {\n          "avatar": {},\n          "country": "",\n          "display_name": "",\n          "public_nick_name": "",\n          "uuid": ""\n        },\n        "merchant_category_code": "",\n        "swift_account_number": "",\n        "swift_bic": "",\n        "transferwise_account_number": "",\n        "transferwise_bank_code": ""\n      },\n      "category": "",\n      "chamber_of_commerce_number": "",\n      "counterparty_address": {},\n      "counterparty_alias": {},\n      "created": "",\n      "description": "",\n      "external_url": "",\n      "group": [\n        {\n          "instance_description": "",\n          "item": [\n            {\n              "billing_date": "",\n              "id": 0,\n              "quantity": 0,\n              "total_vat_exclusive": {\n                "currency": "",\n                "value": ""\n              },\n              "total_vat_inclusive": {},\n              "type_description": "",\n              "type_description_translated": "",\n              "unit_vat_exclusive": {},\n              "unit_vat_inclusive": {},\n              "vat": 0\n            }\n          ],\n          "product_vat_exclusive": {},\n          "product_vat_inclusive": {},\n          "type": "",\n          "type_description": "",\n          "type_description_translated": ""\n        }\n      ],\n      "id": 0,\n      "invoice_date": "",\n      "invoice_number": "",\n      "request_reference_split_the_bill": [\n        {\n          "id": 0,\n          "type": ""\n        }\n      ],\n      "status": "",\n      "total_vat": {},\n      "total_vat_exclusive": {},\n      "total_vat_inclusive": {},\n      "updated": "",\n      "vat_number": ""\n    },\n    "DraftPayment": {\n      "entries": [\n        {\n          "alias": {},\n          "amount": {},\n          "attachment": [\n            {\n              "id": 0,\n              "monetary_account_id": 0\n            }\n          ],\n          "counterparty_alias": {},\n          "description": "",\n          "id": 0,\n          "merchant_reference": "",\n          "type": ""\n        }\n      ],\n      "number_of_required_accepts": 0,\n      "previous_updated_timestamp": "",\n      "schedule": {\n        "object": {\n          "Payment": {\n            "address_billing": {},\n            "address_shipping": {},\n            "alias": {},\n            "allow_bunqto": false,\n            "amount": {},\n            "attachment": [\n              {}\n            ],\n            "balance_after_mutation": {},\n            "batch_id": 0,\n            "bunqto_expiry": "",\n            "bunqto_share_url": "",\n            "bunqto_status": "",\n            "bunqto_sub_status": "",\n            "bunqto_time_responded": "",\n            "counterparty_alias": {},\n            "created": "",\n            "description": "",\n            "geolocation": {\n              "altitude": 0,\n              "latitude": 0,\n              "longitude": 0,\n              "radius": 0\n            },\n            "id": 0,\n            "merchant_reference": "",\n            "monetary_account_id": 0,\n            "payment_auto_allocate_instance": {\n              "created": "",\n              "error_message": [],\n              "id": 0,\n              "payment_auto_allocate_id": 0,\n              "payment_batch": {\n                "payments": {\n                  "Payment": []\n                }\n              },\n              "payment_id": 0,\n              "status": "",\n              "updated": ""\n            },\n            "request_reference_split_the_bill": [\n              {}\n            ],\n            "scheduled_id": 0,\n            "sub_type": "",\n            "type": "",\n            "updated": ""\n          },\n          "PaymentBatch": {}\n        },\n        "recurrence_size": 0,\n        "recurrence_unit": "",\n        "status": "",\n        "time_end": "",\n        "time_start": ""\n      },\n      "status": ""\n    },\n    "MasterCardAction": {\n      "alias": {},\n      "all_mastercard_action_refund": [\n        {\n          "additional_information": {\n            "attachment": [\n              {\n                "id": 0\n              }\n            ],\n            "category": "",\n            "comment": "",\n            "reason": "",\n            "terms_and_conditions": ""\n          },\n          "alias": {},\n          "amount": {},\n          "attachment": [\n            {}\n          ],\n          "category": "",\n          "comment": "",\n          "counterparty_alias": {},\n          "created": "",\n          "description": "",\n          "id": 0,\n          "label_card": {\n            "expiry_date": "",\n            "label_user": {},\n            "second_line": "",\n            "status": "",\n            "type": "",\n            "uuid": ""\n          },\n          "label_user_creator": {},\n          "mastercard_action_id": 0,\n          "reason": "",\n          "reference_mastercard_action_event": [\n            {\n              "event_id": 0\n            }\n          ],\n          "status": "",\n          "status_description": "",\n          "status_description_translated": "",\n          "status_together_url": "",\n          "sub_type": "",\n          "terms_and_conditions": "",\n          "time_refund": "",\n          "type": "",\n          "updated": ""\n        }\n      ],\n      "amount_billing": {},\n      "amount_converted": {},\n      "amount_fee": {},\n      "amount_local": {},\n      "amount_original_billing": {},\n      "amount_original_local": {},\n      "applied_limit": "",\n      "authorisation_status": "",\n      "authorisation_type": "",\n      "card_authorisation_id_response": "",\n      "card_id": 0,\n      "city": "",\n      "clearing_expiry_time": "",\n      "clearing_status": "",\n      "counterparty_alias": {},\n      "decision": "",\n      "decision_description": "",\n      "decision_description_translated": "",\n      "decision_together_url": "",\n      "description": "",\n      "eligible_whitelist_id": 0,\n      "id": 0,\n      "label_card": {},\n      "maturity_date": "",\n      "monetary_account_id": 0,\n      "pan_entry_mode_user": "",\n      "payment_status": "",\n      "pos_card_holder_presence": "",\n      "pos_card_presence": "",\n      "request_reference_split_the_bill": [\n        {}\n      ],\n      "reservation_expiry_time": "",\n      "secure_code_id": 0,\n      "settlement_status": "",\n      "token_status": "",\n      "wallet_provider_id": ""\n    },\n    "Payment": {},\n    "PaymentBatch": {},\n    "RequestResponse": {\n      "address_billing": {},\n      "address_shipping": {},\n      "alias": {},\n      "amount_inquired": {},\n      "amount_responded": {},\n      "attachment": [\n        {\n          "content_type": "",\n          "description": "",\n          "urls": [\n            {\n              "type": "",\n              "url": ""\n            }\n          ]\n        }\n      ],\n      "counterparty_alias": {},\n      "created": "",\n      "credit_scheme_identifier": "",\n      "description": "",\n      "eligible_whitelist_id": 0,\n      "event_id": 0,\n      "geolocation": {},\n      "id": 0,\n      "mandate_identifier": "",\n      "minimum_age": 0,\n      "monetary_account_id": 0,\n      "redirect_url": "",\n      "request_reference_split_the_bill": [\n        {}\n      ],\n      "require_address": "",\n      "status": "",\n      "sub_type": "",\n      "time_expiry": "",\n      "time_refund_requested": "",\n      "time_refunded": "",\n      "time_responded": "",\n      "type": "",\n      "updated": "",\n      "user_refund_requested": {}\n    },\n    "ScheduleInstance": {\n      "error_message": [],\n      "request_reference_split_the_bill": [\n        {}\n      ],\n      "result_object": {\n        "Payment": {},\n        "PaymentBatch": {}\n      },\n      "scheduled_object": {},\n      "state": "",\n      "time_end": "",\n      "time_start": ""\n    },\n    "TransferwisePayment": {\n      "alias": {},\n      "amount_source": {},\n      "amount_target": {},\n      "counterparty_alias": {},\n      "monetary_account_id": "",\n      "pay_in_reference": "",\n      "quote": {\n        "amount_fee": {},\n        "amount_source": {},\n        "amount_target": {},\n        "created": "",\n        "currency_source": "",\n        "currency_target": "",\n        "id": 0,\n        "quote_id": "",\n        "rate": "",\n        "time_delivery_estimate": "",\n        "time_expiry": "",\n        "updated": ""\n      },\n      "rate": "",\n      "recipient_id": "",\n      "reference": "",\n      "status": "",\n      "status_transferwise": "",\n      "status_transferwise_issue": "",\n      "sub_status": "",\n      "time_delivery_estimate": ""\n    },\n    "WhitelistResult": {\n      "error_message": [],\n      "id": 0,\n      "monetary_account_paying_id": 0,\n      "object": {\n        "draftPayment": {},\n        "id": 0,\n        "requestResponse": {}\n      },\n      "request_reference_split_the_bill": [\n        {}\n      ],\n      "status": "",\n      "sub_status": "",\n      "whitelist": {}\n    }\n  },\n  "request_inquiries": [\n    {\n      "address_billing": {},\n      "address_shipping": {},\n      "allow_amount_higher": false,\n      "allow_amount_lower": false,\n      "allow_bunqme": false,\n      "amount_inquired": {},\n      "amount_responded": {},\n      "attachment": [\n        {\n          "id": 0\n        }\n      ],\n      "batch_id": 0,\n      "bunqme_share_url": "",\n      "counterparty_alias": {},\n      "created": "",\n      "description": "",\n      "event_id": 0,\n      "geolocation": {},\n      "id": 0,\n      "merchant_reference": "",\n      "minimum_age": 0,\n      "monetary_account_id": 0,\n      "redirect_url": "",\n      "reference_split_the_bill": {},\n      "require_address": "",\n      "scheduled_id": 0,\n      "status": "",\n      "time_expiry": "",\n      "time_responded": "",\n      "updated": "",\n      "user_alias_created": {},\n      "user_alias_revoked": {},\n      "want_tip": false\n    }\n  ],\n  "status": "",\n  "total_amount_inquired": {}\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"event_id\": 0,\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {\n                \"currency\": \"\",\n                \"value\": \"\"\n              },\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {\n              \"altitude\": 0,\n              \"latitude\": 0,\n              \"longitude\": 0,\n              \"radius\": 0\n            },\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"request_inquiries\": [\n    {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"allow_amount_higher\": false,\n      \"allow_amount_lower\": false,\n      \"allow_bunqme\": false,\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"id\": 0\n        }\n      ],\n      \"batch_id\": 0,\n      \"bunqme_share_url\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"reference_split_the_bill\": {},\n      \"require_address\": \"\",\n      \"scheduled_id\": 0,\n      \"status\": \"\",\n      \"time_expiry\": \"\",\n      \"time_responded\": \"\",\n      \"updated\": \"\",\n      \"user_alias_created\": {},\n      \"user_alias_revoked\": {},\n      \"want_tip\": false\n    }\n  ],\n  \"status\": \"\",\n  \"total_amount_inquired\": {}\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  event_id: 0,
  reference_split_the_bill: {
    BillingInvoice: {
      address: {
        city: '',
        country: '',
        extra: '',
        house_number: '',
        is_user_address_updated: false,
        mailbox_name: '',
        po_box: '',
        postal_code: '',
        province: '',
        street: ''
      },
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
          style: '',
          uuid: ''
        },
        bunq_me: {name: '', service: '', type: '', value: ''},
        country: '',
        display_name: '',
        iban: '',
        is_light: false,
        label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
        merchant_category_code: '',
        swift_account_number: '',
        swift_bic: '',
        transferwise_account_number: '',
        transferwise_bank_code: ''
      },
      category: '',
      chamber_of_commerce_number: '',
      counterparty_address: {},
      counterparty_alias: {},
      created: '',
      description: '',
      external_url: '',
      group: [
        {
          instance_description: '',
          item: [
            {
              billing_date: '',
              id: 0,
              quantity: 0,
              total_vat_exclusive: {currency: '', value: ''},
              total_vat_inclusive: {},
              type_description: '',
              type_description_translated: '',
              unit_vat_exclusive: {},
              unit_vat_inclusive: {},
              vat: 0
            }
          ],
          product_vat_exclusive: {},
          product_vat_inclusive: {},
          type: '',
          type_description: '',
          type_description_translated: ''
        }
      ],
      id: 0,
      invoice_date: '',
      invoice_number: '',
      request_reference_split_the_bill: [{id: 0, type: ''}],
      status: '',
      total_vat: {},
      total_vat_exclusive: {},
      total_vat_inclusive: {},
      updated: '',
      vat_number: ''
    },
    DraftPayment: {
      entries: [
        {
          alias: {},
          amount: {},
          attachment: [{id: 0, monetary_account_id: 0}],
          counterparty_alias: {},
          description: '',
          id: 0,
          merchant_reference: '',
          type: ''
        }
      ],
      number_of_required_accepts: 0,
      previous_updated_timestamp: '',
      schedule: {
        object: {
          Payment: {
            address_billing: {},
            address_shipping: {},
            alias: {},
            allow_bunqto: false,
            amount: {},
            attachment: [{}],
            balance_after_mutation: {},
            batch_id: 0,
            bunqto_expiry: '',
            bunqto_share_url: '',
            bunqto_status: '',
            bunqto_sub_status: '',
            bunqto_time_responded: '',
            counterparty_alias: {},
            created: '',
            description: '',
            geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
            id: 0,
            merchant_reference: '',
            monetary_account_id: 0,
            payment_auto_allocate_instance: {
              created: '',
              error_message: [],
              id: 0,
              payment_auto_allocate_id: 0,
              payment_batch: {payments: {Payment: []}},
              payment_id: 0,
              status: '',
              updated: ''
            },
            request_reference_split_the_bill: [{}],
            scheduled_id: 0,
            sub_type: '',
            type: '',
            updated: ''
          },
          PaymentBatch: {}
        },
        recurrence_size: 0,
        recurrence_unit: '',
        status: '',
        time_end: '',
        time_start: ''
      },
      status: ''
    },
    MasterCardAction: {
      alias: {},
      all_mastercard_action_refund: [
        {
          additional_information: {
            attachment: [{id: 0}],
            category: '',
            comment: '',
            reason: '',
            terms_and_conditions: ''
          },
          alias: {},
          amount: {},
          attachment: [{}],
          category: '',
          comment: '',
          counterparty_alias: {},
          created: '',
          description: '',
          id: 0,
          label_card: {
            expiry_date: '',
            label_user: {},
            second_line: '',
            status: '',
            type: '',
            uuid: ''
          },
          label_user_creator: {},
          mastercard_action_id: 0,
          reason: '',
          reference_mastercard_action_event: [{event_id: 0}],
          status: '',
          status_description: '',
          status_description_translated: '',
          status_together_url: '',
          sub_type: '',
          terms_and_conditions: '',
          time_refund: '',
          type: '',
          updated: ''
        }
      ],
      amount_billing: {},
      amount_converted: {},
      amount_fee: {},
      amount_local: {},
      amount_original_billing: {},
      amount_original_local: {},
      applied_limit: '',
      authorisation_status: '',
      authorisation_type: '',
      card_authorisation_id_response: '',
      card_id: 0,
      city: '',
      clearing_expiry_time: '',
      clearing_status: '',
      counterparty_alias: {},
      decision: '',
      decision_description: '',
      decision_description_translated: '',
      decision_together_url: '',
      description: '',
      eligible_whitelist_id: 0,
      id: 0,
      label_card: {},
      maturity_date: '',
      monetary_account_id: 0,
      pan_entry_mode_user: '',
      payment_status: '',
      pos_card_holder_presence: '',
      pos_card_presence: '',
      request_reference_split_the_bill: [{}],
      reservation_expiry_time: '',
      secure_code_id: 0,
      settlement_status: '',
      token_status: '',
      wallet_provider_id: ''
    },
    Payment: {},
    PaymentBatch: {},
    RequestResponse: {
      address_billing: {},
      address_shipping: {},
      alias: {},
      amount_inquired: {},
      amount_responded: {},
      attachment: [{content_type: '', description: '', urls: [{type: '', url: ''}]}],
      counterparty_alias: {},
      created: '',
      credit_scheme_identifier: '',
      description: '',
      eligible_whitelist_id: 0,
      event_id: 0,
      geolocation: {},
      id: 0,
      mandate_identifier: '',
      minimum_age: 0,
      monetary_account_id: 0,
      redirect_url: '',
      request_reference_split_the_bill: [{}],
      require_address: '',
      status: '',
      sub_type: '',
      time_expiry: '',
      time_refund_requested: '',
      time_refunded: '',
      time_responded: '',
      type: '',
      updated: '',
      user_refund_requested: {}
    },
    ScheduleInstance: {
      error_message: [],
      request_reference_split_the_bill: [{}],
      result_object: {Payment: {}, PaymentBatch: {}},
      scheduled_object: {},
      state: '',
      time_end: '',
      time_start: ''
    },
    TransferwisePayment: {
      alias: {},
      amount_source: {},
      amount_target: {},
      counterparty_alias: {},
      monetary_account_id: '',
      pay_in_reference: '',
      quote: {
        amount_fee: {},
        amount_source: {},
        amount_target: {},
        created: '',
        currency_source: '',
        currency_target: '',
        id: 0,
        quote_id: '',
        rate: '',
        time_delivery_estimate: '',
        time_expiry: '',
        updated: ''
      },
      rate: '',
      recipient_id: '',
      reference: '',
      status: '',
      status_transferwise: '',
      status_transferwise_issue: '',
      sub_status: '',
      time_delivery_estimate: ''
    },
    WhitelistResult: {
      error_message: [],
      id: 0,
      monetary_account_paying_id: 0,
      object: {draftPayment: {}, id: 0, requestResponse: {}},
      request_reference_split_the_bill: [{}],
      status: '',
      sub_status: '',
      whitelist: {}
    }
  },
  request_inquiries: [
    {
      address_billing: {},
      address_shipping: {},
      allow_amount_higher: false,
      allow_amount_lower: false,
      allow_bunqme: false,
      amount_inquired: {},
      amount_responded: {},
      attachment: [{id: 0}],
      batch_id: 0,
      bunqme_share_url: '',
      counterparty_alias: {},
      created: '',
      description: '',
      event_id: 0,
      geolocation: {},
      id: 0,
      merchant_reference: '',
      minimum_age: 0,
      monetary_account_id: 0,
      redirect_url: '',
      reference_split_the_bill: {},
      require_address: '',
      scheduled_id: 0,
      status: '',
      time_expiry: '',
      time_responded: '',
      updated: '',
      user_alias_created: {},
      user_alias_revoked: {},
      want_tip: false
    }
  ],
  status: '',
  total_amount_inquired: {}
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    event_id: 0,
    reference_split_the_bill: {
      BillingInvoice: {
        address: {
          city: '',
          country: '',
          extra: '',
          house_number: '',
          is_user_address_updated: false,
          mailbox_name: '',
          po_box: '',
          postal_code: '',
          province: '',
          street: ''
        },
        alias: {
          avatar: {
            anchor_uuid: '',
            image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
            style: '',
            uuid: ''
          },
          bunq_me: {name: '', service: '', type: '', value: ''},
          country: '',
          display_name: '',
          iban: '',
          is_light: false,
          label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
          merchant_category_code: '',
          swift_account_number: '',
          swift_bic: '',
          transferwise_account_number: '',
          transferwise_bank_code: ''
        },
        category: '',
        chamber_of_commerce_number: '',
        counterparty_address: {},
        counterparty_alias: {},
        created: '',
        description: '',
        external_url: '',
        group: [
          {
            instance_description: '',
            item: [
              {
                billing_date: '',
                id: 0,
                quantity: 0,
                total_vat_exclusive: {currency: '', value: ''},
                total_vat_inclusive: {},
                type_description: '',
                type_description_translated: '',
                unit_vat_exclusive: {},
                unit_vat_inclusive: {},
                vat: 0
              }
            ],
            product_vat_exclusive: {},
            product_vat_inclusive: {},
            type: '',
            type_description: '',
            type_description_translated: ''
          }
        ],
        id: 0,
        invoice_date: '',
        invoice_number: '',
        request_reference_split_the_bill: [{id: 0, type: ''}],
        status: '',
        total_vat: {},
        total_vat_exclusive: {},
        total_vat_inclusive: {},
        updated: '',
        vat_number: ''
      },
      DraftPayment: {
        entries: [
          {
            alias: {},
            amount: {},
            attachment: [{id: 0, monetary_account_id: 0}],
            counterparty_alias: {},
            description: '',
            id: 0,
            merchant_reference: '',
            type: ''
          }
        ],
        number_of_required_accepts: 0,
        previous_updated_timestamp: '',
        schedule: {
          object: {
            Payment: {
              address_billing: {},
              address_shipping: {},
              alias: {},
              allow_bunqto: false,
              amount: {},
              attachment: [{}],
              balance_after_mutation: {},
              batch_id: 0,
              bunqto_expiry: '',
              bunqto_share_url: '',
              bunqto_status: '',
              bunqto_sub_status: '',
              bunqto_time_responded: '',
              counterparty_alias: {},
              created: '',
              description: '',
              geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
              id: 0,
              merchant_reference: '',
              monetary_account_id: 0,
              payment_auto_allocate_instance: {
                created: '',
                error_message: [],
                id: 0,
                payment_auto_allocate_id: 0,
                payment_batch: {payments: {Payment: []}},
                payment_id: 0,
                status: '',
                updated: ''
              },
              request_reference_split_the_bill: [{}],
              scheduled_id: 0,
              sub_type: '',
              type: '',
              updated: ''
            },
            PaymentBatch: {}
          },
          recurrence_size: 0,
          recurrence_unit: '',
          status: '',
          time_end: '',
          time_start: ''
        },
        status: ''
      },
      MasterCardAction: {
        alias: {},
        all_mastercard_action_refund: [
          {
            additional_information: {
              attachment: [{id: 0}],
              category: '',
              comment: '',
              reason: '',
              terms_and_conditions: ''
            },
            alias: {},
            amount: {},
            attachment: [{}],
            category: '',
            comment: '',
            counterparty_alias: {},
            created: '',
            description: '',
            id: 0,
            label_card: {
              expiry_date: '',
              label_user: {},
              second_line: '',
              status: '',
              type: '',
              uuid: ''
            },
            label_user_creator: {},
            mastercard_action_id: 0,
            reason: '',
            reference_mastercard_action_event: [{event_id: 0}],
            status: '',
            status_description: '',
            status_description_translated: '',
            status_together_url: '',
            sub_type: '',
            terms_and_conditions: '',
            time_refund: '',
            type: '',
            updated: ''
          }
        ],
        amount_billing: {},
        amount_converted: {},
        amount_fee: {},
        amount_local: {},
        amount_original_billing: {},
        amount_original_local: {},
        applied_limit: '',
        authorisation_status: '',
        authorisation_type: '',
        card_authorisation_id_response: '',
        card_id: 0,
        city: '',
        clearing_expiry_time: '',
        clearing_status: '',
        counterparty_alias: {},
        decision: '',
        decision_description: '',
        decision_description_translated: '',
        decision_together_url: '',
        description: '',
        eligible_whitelist_id: 0,
        id: 0,
        label_card: {},
        maturity_date: '',
        monetary_account_id: 0,
        pan_entry_mode_user: '',
        payment_status: '',
        pos_card_holder_presence: '',
        pos_card_presence: '',
        request_reference_split_the_bill: [{}],
        reservation_expiry_time: '',
        secure_code_id: 0,
        settlement_status: '',
        token_status: '',
        wallet_provider_id: ''
      },
      Payment: {},
      PaymentBatch: {},
      RequestResponse: {
        address_billing: {},
        address_shipping: {},
        alias: {},
        amount_inquired: {},
        amount_responded: {},
        attachment: [{content_type: '', description: '', urls: [{type: '', url: ''}]}],
        counterparty_alias: {},
        created: '',
        credit_scheme_identifier: '',
        description: '',
        eligible_whitelist_id: 0,
        event_id: 0,
        geolocation: {},
        id: 0,
        mandate_identifier: '',
        minimum_age: 0,
        monetary_account_id: 0,
        redirect_url: '',
        request_reference_split_the_bill: [{}],
        require_address: '',
        status: '',
        sub_type: '',
        time_expiry: '',
        time_refund_requested: '',
        time_refunded: '',
        time_responded: '',
        type: '',
        updated: '',
        user_refund_requested: {}
      },
      ScheduleInstance: {
        error_message: [],
        request_reference_split_the_bill: [{}],
        result_object: {Payment: {}, PaymentBatch: {}},
        scheduled_object: {},
        state: '',
        time_end: '',
        time_start: ''
      },
      TransferwisePayment: {
        alias: {},
        amount_source: {},
        amount_target: {},
        counterparty_alias: {},
        monetary_account_id: '',
        pay_in_reference: '',
        quote: {
          amount_fee: {},
          amount_source: {},
          amount_target: {},
          created: '',
          currency_source: '',
          currency_target: '',
          id: 0,
          quote_id: '',
          rate: '',
          time_delivery_estimate: '',
          time_expiry: '',
          updated: ''
        },
        rate: '',
        recipient_id: '',
        reference: '',
        status: '',
        status_transferwise: '',
        status_transferwise_issue: '',
        sub_status: '',
        time_delivery_estimate: ''
      },
      WhitelistResult: {
        error_message: [],
        id: 0,
        monetary_account_paying_id: 0,
        object: {draftPayment: {}, id: 0, requestResponse: {}},
        request_reference_split_the_bill: [{}],
        status: '',
        sub_status: '',
        whitelist: {}
      }
    },
    request_inquiries: [
      {
        address_billing: {},
        address_shipping: {},
        allow_amount_higher: false,
        allow_amount_lower: false,
        allow_bunqme: false,
        amount_inquired: {},
        amount_responded: {},
        attachment: [{id: 0}],
        batch_id: 0,
        bunqme_share_url: '',
        counterparty_alias: {},
        created: '',
        description: '',
        event_id: 0,
        geolocation: {},
        id: 0,
        merchant_reference: '',
        minimum_age: 0,
        monetary_account_id: 0,
        redirect_url: '',
        reference_split_the_bill: {},
        require_address: '',
        scheduled_id: 0,
        status: '',
        time_expiry: '',
        time_responded: '',
        updated: '',
        user_alias_created: {},
        user_alias_revoked: {},
        want_tip: false
      }
    ],
    status: '',
    total_amount_inquired: {}
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  event_id: 0,
  reference_split_the_bill: {
    BillingInvoice: {
      address: {
        city: '',
        country: '',
        extra: '',
        house_number: '',
        is_user_address_updated: false,
        mailbox_name: '',
        po_box: '',
        postal_code: '',
        province: '',
        street: ''
      },
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [
            {
              attachment_public_uuid: '',
              content_type: '',
              height: 0,
              width: 0
            }
          ],
          style: '',
          uuid: ''
        },
        bunq_me: {
          name: '',
          service: '',
          type: '',
          value: ''
        },
        country: '',
        display_name: '',
        iban: '',
        is_light: false,
        label_user: {
          avatar: {},
          country: '',
          display_name: '',
          public_nick_name: '',
          uuid: ''
        },
        merchant_category_code: '',
        swift_account_number: '',
        swift_bic: '',
        transferwise_account_number: '',
        transferwise_bank_code: ''
      },
      category: '',
      chamber_of_commerce_number: '',
      counterparty_address: {},
      counterparty_alias: {},
      created: '',
      description: '',
      external_url: '',
      group: [
        {
          instance_description: '',
          item: [
            {
              billing_date: '',
              id: 0,
              quantity: 0,
              total_vat_exclusive: {
                currency: '',
                value: ''
              },
              total_vat_inclusive: {},
              type_description: '',
              type_description_translated: '',
              unit_vat_exclusive: {},
              unit_vat_inclusive: {},
              vat: 0
            }
          ],
          product_vat_exclusive: {},
          product_vat_inclusive: {},
          type: '',
          type_description: '',
          type_description_translated: ''
        }
      ],
      id: 0,
      invoice_date: '',
      invoice_number: '',
      request_reference_split_the_bill: [
        {
          id: 0,
          type: ''
        }
      ],
      status: '',
      total_vat: {},
      total_vat_exclusive: {},
      total_vat_inclusive: {},
      updated: '',
      vat_number: ''
    },
    DraftPayment: {
      entries: [
        {
          alias: {},
          amount: {},
          attachment: [
            {
              id: 0,
              monetary_account_id: 0
            }
          ],
          counterparty_alias: {},
          description: '',
          id: 0,
          merchant_reference: '',
          type: ''
        }
      ],
      number_of_required_accepts: 0,
      previous_updated_timestamp: '',
      schedule: {
        object: {
          Payment: {
            address_billing: {},
            address_shipping: {},
            alias: {},
            allow_bunqto: false,
            amount: {},
            attachment: [
              {}
            ],
            balance_after_mutation: {},
            batch_id: 0,
            bunqto_expiry: '',
            bunqto_share_url: '',
            bunqto_status: '',
            bunqto_sub_status: '',
            bunqto_time_responded: '',
            counterparty_alias: {},
            created: '',
            description: '',
            geolocation: {
              altitude: 0,
              latitude: 0,
              longitude: 0,
              radius: 0
            },
            id: 0,
            merchant_reference: '',
            monetary_account_id: 0,
            payment_auto_allocate_instance: {
              created: '',
              error_message: [],
              id: 0,
              payment_auto_allocate_id: 0,
              payment_batch: {
                payments: {
                  Payment: []
                }
              },
              payment_id: 0,
              status: '',
              updated: ''
            },
            request_reference_split_the_bill: [
              {}
            ],
            scheduled_id: 0,
            sub_type: '',
            type: '',
            updated: ''
          },
          PaymentBatch: {}
        },
        recurrence_size: 0,
        recurrence_unit: '',
        status: '',
        time_end: '',
        time_start: ''
      },
      status: ''
    },
    MasterCardAction: {
      alias: {},
      all_mastercard_action_refund: [
        {
          additional_information: {
            attachment: [
              {
                id: 0
              }
            ],
            category: '',
            comment: '',
            reason: '',
            terms_and_conditions: ''
          },
          alias: {},
          amount: {},
          attachment: [
            {}
          ],
          category: '',
          comment: '',
          counterparty_alias: {},
          created: '',
          description: '',
          id: 0,
          label_card: {
            expiry_date: '',
            label_user: {},
            second_line: '',
            status: '',
            type: '',
            uuid: ''
          },
          label_user_creator: {},
          mastercard_action_id: 0,
          reason: '',
          reference_mastercard_action_event: [
            {
              event_id: 0
            }
          ],
          status: '',
          status_description: '',
          status_description_translated: '',
          status_together_url: '',
          sub_type: '',
          terms_and_conditions: '',
          time_refund: '',
          type: '',
          updated: ''
        }
      ],
      amount_billing: {},
      amount_converted: {},
      amount_fee: {},
      amount_local: {},
      amount_original_billing: {},
      amount_original_local: {},
      applied_limit: '',
      authorisation_status: '',
      authorisation_type: '',
      card_authorisation_id_response: '',
      card_id: 0,
      city: '',
      clearing_expiry_time: '',
      clearing_status: '',
      counterparty_alias: {},
      decision: '',
      decision_description: '',
      decision_description_translated: '',
      decision_together_url: '',
      description: '',
      eligible_whitelist_id: 0,
      id: 0,
      label_card: {},
      maturity_date: '',
      monetary_account_id: 0,
      pan_entry_mode_user: '',
      payment_status: '',
      pos_card_holder_presence: '',
      pos_card_presence: '',
      request_reference_split_the_bill: [
        {}
      ],
      reservation_expiry_time: '',
      secure_code_id: 0,
      settlement_status: '',
      token_status: '',
      wallet_provider_id: ''
    },
    Payment: {},
    PaymentBatch: {},
    RequestResponse: {
      address_billing: {},
      address_shipping: {},
      alias: {},
      amount_inquired: {},
      amount_responded: {},
      attachment: [
        {
          content_type: '',
          description: '',
          urls: [
            {
              type: '',
              url: ''
            }
          ]
        }
      ],
      counterparty_alias: {},
      created: '',
      credit_scheme_identifier: '',
      description: '',
      eligible_whitelist_id: 0,
      event_id: 0,
      geolocation: {},
      id: 0,
      mandate_identifier: '',
      minimum_age: 0,
      monetary_account_id: 0,
      redirect_url: '',
      request_reference_split_the_bill: [
        {}
      ],
      require_address: '',
      status: '',
      sub_type: '',
      time_expiry: '',
      time_refund_requested: '',
      time_refunded: '',
      time_responded: '',
      type: '',
      updated: '',
      user_refund_requested: {}
    },
    ScheduleInstance: {
      error_message: [],
      request_reference_split_the_bill: [
        {}
      ],
      result_object: {
        Payment: {},
        PaymentBatch: {}
      },
      scheduled_object: {},
      state: '',
      time_end: '',
      time_start: ''
    },
    TransferwisePayment: {
      alias: {},
      amount_source: {},
      amount_target: {},
      counterparty_alias: {},
      monetary_account_id: '',
      pay_in_reference: '',
      quote: {
        amount_fee: {},
        amount_source: {},
        amount_target: {},
        created: '',
        currency_source: '',
        currency_target: '',
        id: 0,
        quote_id: '',
        rate: '',
        time_delivery_estimate: '',
        time_expiry: '',
        updated: ''
      },
      rate: '',
      recipient_id: '',
      reference: '',
      status: '',
      status_transferwise: '',
      status_transferwise_issue: '',
      sub_status: '',
      time_delivery_estimate: ''
    },
    WhitelistResult: {
      error_message: [],
      id: 0,
      monetary_account_paying_id: 0,
      object: {
        draftPayment: {},
        id: 0,
        requestResponse: {}
      },
      request_reference_split_the_bill: [
        {}
      ],
      status: '',
      sub_status: '',
      whitelist: {}
    }
  },
  request_inquiries: [
    {
      address_billing: {},
      address_shipping: {},
      allow_amount_higher: false,
      allow_amount_lower: false,
      allow_bunqme: false,
      amount_inquired: {},
      amount_responded: {},
      attachment: [
        {
          id: 0
        }
      ],
      batch_id: 0,
      bunqme_share_url: '',
      counterparty_alias: {},
      created: '',
      description: '',
      event_id: 0,
      geolocation: {},
      id: 0,
      merchant_reference: '',
      minimum_age: 0,
      monetary_account_id: 0,
      redirect_url: '',
      reference_split_the_bill: {},
      require_address: '',
      scheduled_id: 0,
      status: '',
      time_expiry: '',
      time_responded: '',
      updated: '',
      user_alias_created: {},
      user_alias_revoked: {},
      want_tip: false
    }
  ],
  status: '',
  total_amount_inquired: {}
});

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}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    event_id: 0,
    reference_split_the_bill: {
      BillingInvoice: {
        address: {
          city: '',
          country: '',
          extra: '',
          house_number: '',
          is_user_address_updated: false,
          mailbox_name: '',
          po_box: '',
          postal_code: '',
          province: '',
          street: ''
        },
        alias: {
          avatar: {
            anchor_uuid: '',
            image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
            style: '',
            uuid: ''
          },
          bunq_me: {name: '', service: '', type: '', value: ''},
          country: '',
          display_name: '',
          iban: '',
          is_light: false,
          label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
          merchant_category_code: '',
          swift_account_number: '',
          swift_bic: '',
          transferwise_account_number: '',
          transferwise_bank_code: ''
        },
        category: '',
        chamber_of_commerce_number: '',
        counterparty_address: {},
        counterparty_alias: {},
        created: '',
        description: '',
        external_url: '',
        group: [
          {
            instance_description: '',
            item: [
              {
                billing_date: '',
                id: 0,
                quantity: 0,
                total_vat_exclusive: {currency: '', value: ''},
                total_vat_inclusive: {},
                type_description: '',
                type_description_translated: '',
                unit_vat_exclusive: {},
                unit_vat_inclusive: {},
                vat: 0
              }
            ],
            product_vat_exclusive: {},
            product_vat_inclusive: {},
            type: '',
            type_description: '',
            type_description_translated: ''
          }
        ],
        id: 0,
        invoice_date: '',
        invoice_number: '',
        request_reference_split_the_bill: [{id: 0, type: ''}],
        status: '',
        total_vat: {},
        total_vat_exclusive: {},
        total_vat_inclusive: {},
        updated: '',
        vat_number: ''
      },
      DraftPayment: {
        entries: [
          {
            alias: {},
            amount: {},
            attachment: [{id: 0, monetary_account_id: 0}],
            counterparty_alias: {},
            description: '',
            id: 0,
            merchant_reference: '',
            type: ''
          }
        ],
        number_of_required_accepts: 0,
        previous_updated_timestamp: '',
        schedule: {
          object: {
            Payment: {
              address_billing: {},
              address_shipping: {},
              alias: {},
              allow_bunqto: false,
              amount: {},
              attachment: [{}],
              balance_after_mutation: {},
              batch_id: 0,
              bunqto_expiry: '',
              bunqto_share_url: '',
              bunqto_status: '',
              bunqto_sub_status: '',
              bunqto_time_responded: '',
              counterparty_alias: {},
              created: '',
              description: '',
              geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
              id: 0,
              merchant_reference: '',
              monetary_account_id: 0,
              payment_auto_allocate_instance: {
                created: '',
                error_message: [],
                id: 0,
                payment_auto_allocate_id: 0,
                payment_batch: {payments: {Payment: []}},
                payment_id: 0,
                status: '',
                updated: ''
              },
              request_reference_split_the_bill: [{}],
              scheduled_id: 0,
              sub_type: '',
              type: '',
              updated: ''
            },
            PaymentBatch: {}
          },
          recurrence_size: 0,
          recurrence_unit: '',
          status: '',
          time_end: '',
          time_start: ''
        },
        status: ''
      },
      MasterCardAction: {
        alias: {},
        all_mastercard_action_refund: [
          {
            additional_information: {
              attachment: [{id: 0}],
              category: '',
              comment: '',
              reason: '',
              terms_and_conditions: ''
            },
            alias: {},
            amount: {},
            attachment: [{}],
            category: '',
            comment: '',
            counterparty_alias: {},
            created: '',
            description: '',
            id: 0,
            label_card: {
              expiry_date: '',
              label_user: {},
              second_line: '',
              status: '',
              type: '',
              uuid: ''
            },
            label_user_creator: {},
            mastercard_action_id: 0,
            reason: '',
            reference_mastercard_action_event: [{event_id: 0}],
            status: '',
            status_description: '',
            status_description_translated: '',
            status_together_url: '',
            sub_type: '',
            terms_and_conditions: '',
            time_refund: '',
            type: '',
            updated: ''
          }
        ],
        amount_billing: {},
        amount_converted: {},
        amount_fee: {},
        amount_local: {},
        amount_original_billing: {},
        amount_original_local: {},
        applied_limit: '',
        authorisation_status: '',
        authorisation_type: '',
        card_authorisation_id_response: '',
        card_id: 0,
        city: '',
        clearing_expiry_time: '',
        clearing_status: '',
        counterparty_alias: {},
        decision: '',
        decision_description: '',
        decision_description_translated: '',
        decision_together_url: '',
        description: '',
        eligible_whitelist_id: 0,
        id: 0,
        label_card: {},
        maturity_date: '',
        monetary_account_id: 0,
        pan_entry_mode_user: '',
        payment_status: '',
        pos_card_holder_presence: '',
        pos_card_presence: '',
        request_reference_split_the_bill: [{}],
        reservation_expiry_time: '',
        secure_code_id: 0,
        settlement_status: '',
        token_status: '',
        wallet_provider_id: ''
      },
      Payment: {},
      PaymentBatch: {},
      RequestResponse: {
        address_billing: {},
        address_shipping: {},
        alias: {},
        amount_inquired: {},
        amount_responded: {},
        attachment: [{content_type: '', description: '', urls: [{type: '', url: ''}]}],
        counterparty_alias: {},
        created: '',
        credit_scheme_identifier: '',
        description: '',
        eligible_whitelist_id: 0,
        event_id: 0,
        geolocation: {},
        id: 0,
        mandate_identifier: '',
        minimum_age: 0,
        monetary_account_id: 0,
        redirect_url: '',
        request_reference_split_the_bill: [{}],
        require_address: '',
        status: '',
        sub_type: '',
        time_expiry: '',
        time_refund_requested: '',
        time_refunded: '',
        time_responded: '',
        type: '',
        updated: '',
        user_refund_requested: {}
      },
      ScheduleInstance: {
        error_message: [],
        request_reference_split_the_bill: [{}],
        result_object: {Payment: {}, PaymentBatch: {}},
        scheduled_object: {},
        state: '',
        time_end: '',
        time_start: ''
      },
      TransferwisePayment: {
        alias: {},
        amount_source: {},
        amount_target: {},
        counterparty_alias: {},
        monetary_account_id: '',
        pay_in_reference: '',
        quote: {
          amount_fee: {},
          amount_source: {},
          amount_target: {},
          created: '',
          currency_source: '',
          currency_target: '',
          id: 0,
          quote_id: '',
          rate: '',
          time_delivery_estimate: '',
          time_expiry: '',
          updated: ''
        },
        rate: '',
        recipient_id: '',
        reference: '',
        status: '',
        status_transferwise: '',
        status_transferwise_issue: '',
        sub_status: '',
        time_delivery_estimate: ''
      },
      WhitelistResult: {
        error_message: [],
        id: 0,
        monetary_account_paying_id: 0,
        object: {draftPayment: {}, id: 0, requestResponse: {}},
        request_reference_split_the_bill: [{}],
        status: '',
        sub_status: '',
        whitelist: {}
      }
    },
    request_inquiries: [
      {
        address_billing: {},
        address_shipping: {},
        allow_amount_higher: false,
        allow_amount_lower: false,
        allow_bunqme: false,
        amount_inquired: {},
        amount_responded: {},
        attachment: [{id: 0}],
        batch_id: 0,
        bunqme_share_url: '',
        counterparty_alias: {},
        created: '',
        description: '',
        event_id: 0,
        geolocation: {},
        id: 0,
        merchant_reference: '',
        minimum_age: 0,
        monetary_account_id: 0,
        redirect_url: '',
        reference_split_the_bill: {},
        require_address: '',
        scheduled_id: 0,
        status: '',
        time_expiry: '',
        time_responded: '',
        updated: '',
        user_alias_created: {},
        user_alias_revoked: {},
        want_tip: false
      }
    ],
    status: '',
    total_amount_inquired: {}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"event_id":0,"reference_split_the_bill":{"BillingInvoice":{"address":{"city":"","country":"","extra":"","house_number":"","is_user_address_updated":false,"mailbox_name":"","po_box":"","postal_code":"","province":"","street":""},"alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"category":"","chamber_of_commerce_number":"","counterparty_address":{},"counterparty_alias":{},"created":"","description":"","external_url":"","group":[{"instance_description":"","item":[{"billing_date":"","id":0,"quantity":0,"total_vat_exclusive":{"currency":"","value":""},"total_vat_inclusive":{},"type_description":"","type_description_translated":"","unit_vat_exclusive":{},"unit_vat_inclusive":{},"vat":0}],"product_vat_exclusive":{},"product_vat_inclusive":{},"type":"","type_description":"","type_description_translated":""}],"id":0,"invoice_date":"","invoice_number":"","request_reference_split_the_bill":[{"id":0,"type":""}],"status":"","total_vat":{},"total_vat_exclusive":{},"total_vat_inclusive":{},"updated":"","vat_number":""},"DraftPayment":{"entries":[{"alias":{},"amount":{},"attachment":[{"id":0,"monetary_account_id":0}],"counterparty_alias":{},"description":"","id":0,"merchant_reference":"","type":""}],"number_of_required_accepts":0,"previous_updated_timestamp":"","schedule":{"object":{"Payment":{"address_billing":{},"address_shipping":{},"alias":{},"allow_bunqto":false,"amount":{},"attachment":[{}],"balance_after_mutation":{},"batch_id":0,"bunqto_expiry":"","bunqto_share_url":"","bunqto_status":"","bunqto_sub_status":"","bunqto_time_responded":"","counterparty_alias":{},"created":"","description":"","geolocation":{"altitude":0,"latitude":0,"longitude":0,"radius":0},"id":0,"merchant_reference":"","monetary_account_id":0,"payment_auto_allocate_instance":{"created":"","error_message":[],"id":0,"payment_auto_allocate_id":0,"payment_batch":{"payments":{"Payment":[]}},"payment_id":0,"status":"","updated":""},"request_reference_split_the_bill":[{}],"scheduled_id":0,"sub_type":"","type":"","updated":""},"PaymentBatch":{}},"recurrence_size":0,"recurrence_unit":"","status":"","time_end":"","time_start":""},"status":""},"MasterCardAction":{"alias":{},"all_mastercard_action_refund":[{"additional_information":{"attachment":[{"id":0}],"category":"","comment":"","reason":"","terms_and_conditions":""},"alias":{},"amount":{},"attachment":[{}],"category":"","comment":"","counterparty_alias":{},"created":"","description":"","id":0,"label_card":{"expiry_date":"","label_user":{},"second_line":"","status":"","type":"","uuid":""},"label_user_creator":{},"mastercard_action_id":0,"reason":"","reference_mastercard_action_event":[{"event_id":0}],"status":"","status_description":"","status_description_translated":"","status_together_url":"","sub_type":"","terms_and_conditions":"","time_refund":"","type":"","updated":""}],"amount_billing":{},"amount_converted":{},"amount_fee":{},"amount_local":{},"amount_original_billing":{},"amount_original_local":{},"applied_limit":"","authorisation_status":"","authorisation_type":"","card_authorisation_id_response":"","card_id":0,"city":"","clearing_expiry_time":"","clearing_status":"","counterparty_alias":{},"decision":"","decision_description":"","decision_description_translated":"","decision_together_url":"","description":"","eligible_whitelist_id":0,"id":0,"label_card":{},"maturity_date":"","monetary_account_id":0,"pan_entry_mode_user":"","payment_status":"","pos_card_holder_presence":"","pos_card_presence":"","request_reference_split_the_bill":[{}],"reservation_expiry_time":"","secure_code_id":0,"settlement_status":"","token_status":"","wallet_provider_id":""},"Payment":{},"PaymentBatch":{},"RequestResponse":{"address_billing":{},"address_shipping":{},"alias":{},"amount_inquired":{},"amount_responded":{},"attachment":[{"content_type":"","description":"","urls":[{"type":"","url":""}]}],"counterparty_alias":{},"created":"","credit_scheme_identifier":"","description":"","eligible_whitelist_id":0,"event_id":0,"geolocation":{},"id":0,"mandate_identifier":"","minimum_age":0,"monetary_account_id":0,"redirect_url":"","request_reference_split_the_bill":[{}],"require_address":"","status":"","sub_type":"","time_expiry":"","time_refund_requested":"","time_refunded":"","time_responded":"","type":"","updated":"","user_refund_requested":{}},"ScheduleInstance":{"error_message":[],"request_reference_split_the_bill":[{}],"result_object":{"Payment":{},"PaymentBatch":{}},"scheduled_object":{},"state":"","time_end":"","time_start":""},"TransferwisePayment":{"alias":{},"amount_source":{},"amount_target":{},"counterparty_alias":{},"monetary_account_id":"","pay_in_reference":"","quote":{"amount_fee":{},"amount_source":{},"amount_target":{},"created":"","currency_source":"","currency_target":"","id":0,"quote_id":"","rate":"","time_delivery_estimate":"","time_expiry":"","updated":""},"rate":"","recipient_id":"","reference":"","status":"","status_transferwise":"","status_transferwise_issue":"","sub_status":"","time_delivery_estimate":""},"WhitelistResult":{"error_message":[],"id":0,"monetary_account_paying_id":0,"object":{"draftPayment":{},"id":0,"requestResponse":{}},"request_reference_split_the_bill":[{}],"status":"","sub_status":"","whitelist":{}}},"request_inquiries":[{"address_billing":{},"address_shipping":{},"allow_amount_higher":false,"allow_amount_lower":false,"allow_bunqme":false,"amount_inquired":{},"amount_responded":{},"attachment":[{"id":0}],"batch_id":0,"bunqme_share_url":"","counterparty_alias":{},"created":"","description":"","event_id":0,"geolocation":{},"id":0,"merchant_reference":"","minimum_age":0,"monetary_account_id":0,"redirect_url":"","reference_split_the_bill":{},"require_address":"","scheduled_id":0,"status":"","time_expiry":"","time_responded":"","updated":"","user_alias_created":{},"user_alias_revoked":{},"want_tip":false}],"status":"","total_amount_inquired":{}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"event_id": @0,
                              @"reference_split_the_bill": @{ @"BillingInvoice": @{ @"address": @{ @"city": @"", @"country": @"", @"extra": @"", @"house_number": @"", @"is_user_address_updated": @NO, @"mailbox_name": @"", @"po_box": @"", @"postal_code": @"", @"province": @"", @"street": @"" }, @"alias": @{ @"avatar": @{ @"anchor_uuid": @"", @"image": @[ @{ @"attachment_public_uuid": @"", @"content_type": @"", @"height": @0, @"width": @0 } ], @"style": @"", @"uuid": @"" }, @"bunq_me": @{ @"name": @"", @"service": @"", @"type": @"", @"value": @"" }, @"country": @"", @"display_name": @"", @"iban": @"", @"is_light": @NO, @"label_user": @{ @"avatar": @{  }, @"country": @"", @"display_name": @"", @"public_nick_name": @"", @"uuid": @"" }, @"merchant_category_code": @"", @"swift_account_number": @"", @"swift_bic": @"", @"transferwise_account_number": @"", @"transferwise_bank_code": @"" }, @"category": @"", @"chamber_of_commerce_number": @"", @"counterparty_address": @{  }, @"counterparty_alias": @{  }, @"created": @"", @"description": @"", @"external_url": @"", @"group": @[ @{ @"instance_description": @"", @"item": @[ @{ @"billing_date": @"", @"id": @0, @"quantity": @0, @"total_vat_exclusive": @{ @"currency": @"", @"value": @"" }, @"total_vat_inclusive": @{  }, @"type_description": @"", @"type_description_translated": @"", @"unit_vat_exclusive": @{  }, @"unit_vat_inclusive": @{  }, @"vat": @0 } ], @"product_vat_exclusive": @{  }, @"product_vat_inclusive": @{  }, @"type": @"", @"type_description": @"", @"type_description_translated": @"" } ], @"id": @0, @"invoice_date": @"", @"invoice_number": @"", @"request_reference_split_the_bill": @[ @{ @"id": @0, @"type": @"" } ], @"status": @"", @"total_vat": @{  }, @"total_vat_exclusive": @{  }, @"total_vat_inclusive": @{  }, @"updated": @"", @"vat_number": @"" }, @"DraftPayment": @{ @"entries": @[ @{ @"alias": @{  }, @"amount": @{  }, @"attachment": @[ @{ @"id": @0, @"monetary_account_id": @0 } ], @"counterparty_alias": @{  }, @"description": @"", @"id": @0, @"merchant_reference": @"", @"type": @"" } ], @"number_of_required_accepts": @0, @"previous_updated_timestamp": @"", @"schedule": @{ @"object": @{ @"Payment": @{ @"address_billing": @{  }, @"address_shipping": @{  }, @"alias": @{  }, @"allow_bunqto": @NO, @"amount": @{  }, @"attachment": @[ @{  } ], @"balance_after_mutation": @{  }, @"batch_id": @0, @"bunqto_expiry": @"", @"bunqto_share_url": @"", @"bunqto_status": @"", @"bunqto_sub_status": @"", @"bunqto_time_responded": @"", @"counterparty_alias": @{  }, @"created": @"", @"description": @"", @"geolocation": @{ @"altitude": @0, @"latitude": @0, @"longitude": @0, @"radius": @0 }, @"id": @0, @"merchant_reference": @"", @"monetary_account_id": @0, @"payment_auto_allocate_instance": @{ @"created": @"", @"error_message": @[  ], @"id": @0, @"payment_auto_allocate_id": @0, @"payment_batch": @{ @"payments": @{ @"Payment": @[  ] } }, @"payment_id": @0, @"status": @"", @"updated": @"" }, @"request_reference_split_the_bill": @[ @{  } ], @"scheduled_id": @0, @"sub_type": @"", @"type": @"", @"updated": @"" }, @"PaymentBatch": @{  } }, @"recurrence_size": @0, @"recurrence_unit": @"", @"status": @"", @"time_end": @"", @"time_start": @"" }, @"status": @"" }, @"MasterCardAction": @{ @"alias": @{  }, @"all_mastercard_action_refund": @[ @{ @"additional_information": @{ @"attachment": @[ @{ @"id": @0 } ], @"category": @"", @"comment": @"", @"reason": @"", @"terms_and_conditions": @"" }, @"alias": @{  }, @"amount": @{  }, @"attachment": @[ @{  } ], @"category": @"", @"comment": @"", @"counterparty_alias": @{  }, @"created": @"", @"description": @"", @"id": @0, @"label_card": @{ @"expiry_date": @"", @"label_user": @{  }, @"second_line": @"", @"status": @"", @"type": @"", @"uuid": @"" }, @"label_user_creator": @{  }, @"mastercard_action_id": @0, @"reason": @"", @"reference_mastercard_action_event": @[ @{ @"event_id": @0 } ], @"status": @"", @"status_description": @"", @"status_description_translated": @"", @"status_together_url": @"", @"sub_type": @"", @"terms_and_conditions": @"", @"time_refund": @"", @"type": @"", @"updated": @"" } ], @"amount_billing": @{  }, @"amount_converted": @{  }, @"amount_fee": @{  }, @"amount_local": @{  }, @"amount_original_billing": @{  }, @"amount_original_local": @{  }, @"applied_limit": @"", @"authorisation_status": @"", @"authorisation_type": @"", @"card_authorisation_id_response": @"", @"card_id": @0, @"city": @"", @"clearing_expiry_time": @"", @"clearing_status": @"", @"counterparty_alias": @{  }, @"decision": @"", @"decision_description": @"", @"decision_description_translated": @"", @"decision_together_url": @"", @"description": @"", @"eligible_whitelist_id": @0, @"id": @0, @"label_card": @{  }, @"maturity_date": @"", @"monetary_account_id": @0, @"pan_entry_mode_user": @"", @"payment_status": @"", @"pos_card_holder_presence": @"", @"pos_card_presence": @"", @"request_reference_split_the_bill": @[ @{  } ], @"reservation_expiry_time": @"", @"secure_code_id": @0, @"settlement_status": @"", @"token_status": @"", @"wallet_provider_id": @"" }, @"Payment": @{  }, @"PaymentBatch": @{  }, @"RequestResponse": @{ @"address_billing": @{  }, @"address_shipping": @{  }, @"alias": @{  }, @"amount_inquired": @{  }, @"amount_responded": @{  }, @"attachment": @[ @{ @"content_type": @"", @"description": @"", @"urls": @[ @{ @"type": @"", @"url": @"" } ] } ], @"counterparty_alias": @{  }, @"created": @"", @"credit_scheme_identifier": @"", @"description": @"", @"eligible_whitelist_id": @0, @"event_id": @0, @"geolocation": @{  }, @"id": @0, @"mandate_identifier": @"", @"minimum_age": @0, @"monetary_account_id": @0, @"redirect_url": @"", @"request_reference_split_the_bill": @[ @{  } ], @"require_address": @"", @"status": @"", @"sub_type": @"", @"time_expiry": @"", @"time_refund_requested": @"", @"time_refunded": @"", @"time_responded": @"", @"type": @"", @"updated": @"", @"user_refund_requested": @{  } }, @"ScheduleInstance": @{ @"error_message": @[  ], @"request_reference_split_the_bill": @[ @{  } ], @"result_object": @{ @"Payment": @{  }, @"PaymentBatch": @{  } }, @"scheduled_object": @{  }, @"state": @"", @"time_end": @"", @"time_start": @"" }, @"TransferwisePayment": @{ @"alias": @{  }, @"amount_source": @{  }, @"amount_target": @{  }, @"counterparty_alias": @{  }, @"monetary_account_id": @"", @"pay_in_reference": @"", @"quote": @{ @"amount_fee": @{  }, @"amount_source": @{  }, @"amount_target": @{  }, @"created": @"", @"currency_source": @"", @"currency_target": @"", @"id": @0, @"quote_id": @"", @"rate": @"", @"time_delivery_estimate": @"", @"time_expiry": @"", @"updated": @"" }, @"rate": @"", @"recipient_id": @"", @"reference": @"", @"status": @"", @"status_transferwise": @"", @"status_transferwise_issue": @"", @"sub_status": @"", @"time_delivery_estimate": @"" }, @"WhitelistResult": @{ @"error_message": @[  ], @"id": @0, @"monetary_account_paying_id": @0, @"object": @{ @"draftPayment": @{  }, @"id": @0, @"requestResponse": @{  } }, @"request_reference_split_the_bill": @[ @{  } ], @"status": @"", @"sub_status": @"", @"whitelist": @{  } } },
                              @"request_inquiries": @[ @{ @"address_billing": @{  }, @"address_shipping": @{  }, @"allow_amount_higher": @NO, @"allow_amount_lower": @NO, @"allow_bunqme": @NO, @"amount_inquired": @{  }, @"amount_responded": @{  }, @"attachment": @[ @{ @"id": @0 } ], @"batch_id": @0, @"bunqme_share_url": @"", @"counterparty_alias": @{  }, @"created": @"", @"description": @"", @"event_id": @0, @"geolocation": @{  }, @"id": @0, @"merchant_reference": @"", @"minimum_age": @0, @"monetary_account_id": @0, @"redirect_url": @"", @"reference_split_the_bill": @{  }, @"require_address": @"", @"scheduled_id": @0, @"status": @"", @"time_expiry": @"", @"time_responded": @"", @"updated": @"", @"user_alias_created": @{  }, @"user_alias_revoked": @{  }, @"want_tip": @NO } ],
                              @"status": @"",
                              @"total_amount_inquired": @{  } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"event_id\": 0,\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {\n                \"currency\": \"\",\n                \"value\": \"\"\n              },\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {\n              \"altitude\": 0,\n              \"latitude\": 0,\n              \"longitude\": 0,\n              \"radius\": 0\n            },\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"request_inquiries\": [\n    {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"allow_amount_higher\": false,\n      \"allow_amount_lower\": false,\n      \"allow_bunqme\": false,\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"id\": 0\n        }\n      ],\n      \"batch_id\": 0,\n      \"bunqme_share_url\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"reference_split_the_bill\": {},\n      \"require_address\": \"\",\n      \"scheduled_id\": 0,\n      \"status\": \"\",\n      \"time_expiry\": \"\",\n      \"time_responded\": \"\",\n      \"updated\": \"\",\n      \"user_alias_created\": {},\n      \"user_alias_revoked\": {},\n      \"want_tip\": false\n    }\n  ],\n  \"status\": \"\",\n  \"total_amount_inquired\": {}\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'event_id' => 0,
    'reference_split_the_bill' => [
        'BillingInvoice' => [
                'address' => [
                                'city' => '',
                                'country' => '',
                                'extra' => '',
                                'house_number' => '',
                                'is_user_address_updated' => null,
                                'mailbox_name' => '',
                                'po_box' => '',
                                'postal_code' => '',
                                'province' => '',
                                'street' => ''
                ],
                'alias' => [
                                'avatar' => [
                                                                'anchor_uuid' => '',
                                                                'image' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'attachment_public_uuid' => '',
                                                                                                                                                                                                                                                                'content_type' => '',
                                                                                                                                                                                                                                                                'height' => 0,
                                                                                                                                                                                                                                                                'width' => 0
                                                                                                                                ]
                                                                ],
                                                                'style' => '',
                                                                'uuid' => ''
                                ],
                                'bunq_me' => [
                                                                'name' => '',
                                                                'service' => '',
                                                                'type' => '',
                                                                'value' => ''
                                ],
                                'country' => '',
                                'display_name' => '',
                                'iban' => '',
                                'is_light' => null,
                                'label_user' => [
                                                                'avatar' => [
                                                                                                                                
                                                                ],
                                                                'country' => '',
                                                                'display_name' => '',
                                                                'public_nick_name' => '',
                                                                'uuid' => ''
                                ],
                                'merchant_category_code' => '',
                                'swift_account_number' => '',
                                'swift_bic' => '',
                                'transferwise_account_number' => '',
                                'transferwise_bank_code' => ''
                ],
                'category' => '',
                'chamber_of_commerce_number' => '',
                'counterparty_address' => [
                                
                ],
                'counterparty_alias' => [
                                
                ],
                'created' => '',
                'description' => '',
                'external_url' => '',
                'group' => [
                                [
                                                                'instance_description' => '',
                                                                'item' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'billing_date' => '',
                                                                                                                                                                                                                                                                'id' => 0,
                                                                                                                                                                                                                                                                'quantity' => 0,
                                                                                                                                                                                                                                                                'total_vat_exclusive' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'currency' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'value' => ''
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'total_vat_inclusive' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'type_description' => '',
                                                                                                                                                                                                                                                                'type_description_translated' => '',
                                                                                                                                                                                                                                                                'unit_vat_exclusive' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'unit_vat_inclusive' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'vat' => 0
                                                                                                                                ]
                                                                ],
                                                                'product_vat_exclusive' => [
                                                                                                                                
                                                                ],
                                                                'product_vat_inclusive' => [
                                                                                                                                
                                                                ],
                                                                'type' => '',
                                                                'type_description' => '',
                                                                'type_description_translated' => ''
                                ]
                ],
                'id' => 0,
                'invoice_date' => '',
                'invoice_number' => '',
                'request_reference_split_the_bill' => [
                                [
                                                                'id' => 0,
                                                                'type' => ''
                                ]
                ],
                'status' => '',
                'total_vat' => [
                                
                ],
                'total_vat_exclusive' => [
                                
                ],
                'total_vat_inclusive' => [
                                
                ],
                'updated' => '',
                'vat_number' => ''
        ],
        'DraftPayment' => [
                'entries' => [
                                [
                                                                'alias' => [
                                                                                                                                
                                                                ],
                                                                'amount' => [
                                                                                                                                
                                                                ],
                                                                'attachment' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'id' => 0,
                                                                                                                                                                                                                                                                'monetary_account_id' => 0
                                                                                                                                ]
                                                                ],
                                                                'counterparty_alias' => [
                                                                                                                                
                                                                ],
                                                                'description' => '',
                                                                'id' => 0,
                                                                'merchant_reference' => '',
                                                                'type' => ''
                                ]
                ],
                'number_of_required_accepts' => 0,
                'previous_updated_timestamp' => '',
                'schedule' => [
                                'object' => [
                                                                'Payment' => [
                                                                                                                                'address_billing' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'address_shipping' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'alias' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'allow_bunqto' => null,
                                                                                                                                'amount' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'attachment' => [
                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'balance_after_mutation' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'batch_id' => 0,
                                                                                                                                'bunqto_expiry' => '',
                                                                                                                                'bunqto_share_url' => '',
                                                                                                                                'bunqto_status' => '',
                                                                                                                                'bunqto_sub_status' => '',
                                                                                                                                'bunqto_time_responded' => '',
                                                                                                                                'counterparty_alias' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'created' => '',
                                                                                                                                'description' => '',
                                                                                                                                'geolocation' => [
                                                                                                                                                                                                                                                                'altitude' => 0,
                                                                                                                                                                                                                                                                'latitude' => 0,
                                                                                                                                                                                                                                                                'longitude' => 0,
                                                                                                                                                                                                                                                                'radius' => 0
                                                                                                                                ],
                                                                                                                                'id' => 0,
                                                                                                                                'merchant_reference' => '',
                                                                                                                                'monetary_account_id' => 0,
                                                                                                                                'payment_auto_allocate_instance' => [
                                                                                                                                                                                                                                                                'created' => '',
                                                                                                                                                                                                                                                                'error_message' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'id' => 0,
                                                                                                                                                                                                                                                                'payment_auto_allocate_id' => 0,
                                                                                                                                                                                                                                                                'payment_batch' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'payments' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'Payment' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'payment_id' => 0,
                                                                                                                                                                                                                                                                'status' => '',
                                                                                                                                                                                                                                                                'updated' => ''
                                                                                                                                ],
                                                                                                                                'request_reference_split_the_bill' => [
                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'scheduled_id' => 0,
                                                                                                                                'sub_type' => '',
                                                                                                                                'type' => '',
                                                                                                                                'updated' => ''
                                                                ],
                                                                'PaymentBatch' => [
                                                                                                                                
                                                                ]
                                ],
                                'recurrence_size' => 0,
                                'recurrence_unit' => '',
                                'status' => '',
                                'time_end' => '',
                                'time_start' => ''
                ],
                'status' => ''
        ],
        'MasterCardAction' => [
                'alias' => [
                                
                ],
                'all_mastercard_action_refund' => [
                                [
                                                                'additional_information' => [
                                                                                                                                'attachment' => [
                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'id' => 0
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'category' => '',
                                                                                                                                'comment' => '',
                                                                                                                                'reason' => '',
                                                                                                                                'terms_and_conditions' => ''
                                                                ],
                                                                'alias' => [
                                                                                                                                
                                                                ],
                                                                'amount' => [
                                                                                                                                
                                                                ],
                                                                'attachment' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'category' => '',
                                                                'comment' => '',
                                                                'counterparty_alias' => [
                                                                                                                                
                                                                ],
                                                                'created' => '',
                                                                'description' => '',
                                                                'id' => 0,
                                                                'label_card' => [
                                                                                                                                'expiry_date' => '',
                                                                                                                                'label_user' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'second_line' => '',
                                                                                                                                'status' => '',
                                                                                                                                'type' => '',
                                                                                                                                'uuid' => ''
                                                                ],
                                                                'label_user_creator' => [
                                                                                                                                
                                                                ],
                                                                'mastercard_action_id' => 0,
                                                                'reason' => '',
                                                                'reference_mastercard_action_event' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'event_id' => 0
                                                                                                                                ]
                                                                ],
                                                                'status' => '',
                                                                'status_description' => '',
                                                                'status_description_translated' => '',
                                                                'status_together_url' => '',
                                                                'sub_type' => '',
                                                                'terms_and_conditions' => '',
                                                                'time_refund' => '',
                                                                'type' => '',
                                                                'updated' => ''
                                ]
                ],
                'amount_billing' => [
                                
                ],
                'amount_converted' => [
                                
                ],
                'amount_fee' => [
                                
                ],
                'amount_local' => [
                                
                ],
                'amount_original_billing' => [
                                
                ],
                'amount_original_local' => [
                                
                ],
                'applied_limit' => '',
                'authorisation_status' => '',
                'authorisation_type' => '',
                'card_authorisation_id_response' => '',
                'card_id' => 0,
                'city' => '',
                'clearing_expiry_time' => '',
                'clearing_status' => '',
                'counterparty_alias' => [
                                
                ],
                'decision' => '',
                'decision_description' => '',
                'decision_description_translated' => '',
                'decision_together_url' => '',
                'description' => '',
                'eligible_whitelist_id' => 0,
                'id' => 0,
                'label_card' => [
                                
                ],
                'maturity_date' => '',
                'monetary_account_id' => 0,
                'pan_entry_mode_user' => '',
                'payment_status' => '',
                'pos_card_holder_presence' => '',
                'pos_card_presence' => '',
                'request_reference_split_the_bill' => [
                                [
                                                                
                                ]
                ],
                'reservation_expiry_time' => '',
                'secure_code_id' => 0,
                'settlement_status' => '',
                'token_status' => '',
                'wallet_provider_id' => ''
        ],
        'Payment' => [
                
        ],
        'PaymentBatch' => [
                
        ],
        'RequestResponse' => [
                'address_billing' => [
                                
                ],
                'address_shipping' => [
                                
                ],
                'alias' => [
                                
                ],
                'amount_inquired' => [
                                
                ],
                'amount_responded' => [
                                
                ],
                'attachment' => [
                                [
                                                                'content_type' => '',
                                                                'description' => '',
                                                                'urls' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'type' => '',
                                                                                                                                                                                                                                                                'url' => ''
                                                                                                                                ]
                                                                ]
                                ]
                ],
                'counterparty_alias' => [
                                
                ],
                'created' => '',
                'credit_scheme_identifier' => '',
                'description' => '',
                'eligible_whitelist_id' => 0,
                'event_id' => 0,
                'geolocation' => [
                                
                ],
                'id' => 0,
                'mandate_identifier' => '',
                'minimum_age' => 0,
                'monetary_account_id' => 0,
                'redirect_url' => '',
                'request_reference_split_the_bill' => [
                                [
                                                                
                                ]
                ],
                'require_address' => '',
                'status' => '',
                'sub_type' => '',
                'time_expiry' => '',
                'time_refund_requested' => '',
                'time_refunded' => '',
                'time_responded' => '',
                'type' => '',
                'updated' => '',
                'user_refund_requested' => [
                                
                ]
        ],
        'ScheduleInstance' => [
                'error_message' => [
                                
                ],
                'request_reference_split_the_bill' => [
                                [
                                                                
                                ]
                ],
                'result_object' => [
                                'Payment' => [
                                                                
                                ],
                                'PaymentBatch' => [
                                                                
                                ]
                ],
                'scheduled_object' => [
                                
                ],
                'state' => '',
                'time_end' => '',
                'time_start' => ''
        ],
        'TransferwisePayment' => [
                'alias' => [
                                
                ],
                'amount_source' => [
                                
                ],
                'amount_target' => [
                                
                ],
                'counterparty_alias' => [
                                
                ],
                'monetary_account_id' => '',
                'pay_in_reference' => '',
                'quote' => [
                                'amount_fee' => [
                                                                
                                ],
                                'amount_source' => [
                                                                
                                ],
                                'amount_target' => [
                                                                
                                ],
                                'created' => '',
                                'currency_source' => '',
                                'currency_target' => '',
                                'id' => 0,
                                'quote_id' => '',
                                'rate' => '',
                                'time_delivery_estimate' => '',
                                'time_expiry' => '',
                                'updated' => ''
                ],
                'rate' => '',
                'recipient_id' => '',
                'reference' => '',
                'status' => '',
                'status_transferwise' => '',
                'status_transferwise_issue' => '',
                'sub_status' => '',
                'time_delivery_estimate' => ''
        ],
        'WhitelistResult' => [
                'error_message' => [
                                
                ],
                'id' => 0,
                'monetary_account_paying_id' => 0,
                'object' => [
                                'draftPayment' => [
                                                                
                                ],
                                'id' => 0,
                                'requestResponse' => [
                                                                
                                ]
                ],
                'request_reference_split_the_bill' => [
                                [
                                                                
                                ]
                ],
                'status' => '',
                'sub_status' => '',
                'whitelist' => [
                                
                ]
        ]
    ],
    'request_inquiries' => [
        [
                'address_billing' => [
                                
                ],
                'address_shipping' => [
                                
                ],
                'allow_amount_higher' => null,
                'allow_amount_lower' => null,
                'allow_bunqme' => null,
                'amount_inquired' => [
                                
                ],
                'amount_responded' => [
                                
                ],
                'attachment' => [
                                [
                                                                'id' => 0
                                ]
                ],
                'batch_id' => 0,
                'bunqme_share_url' => '',
                'counterparty_alias' => [
                                
                ],
                'created' => '',
                'description' => '',
                'event_id' => 0,
                'geolocation' => [
                                
                ],
                'id' => 0,
                'merchant_reference' => '',
                'minimum_age' => 0,
                'monetary_account_id' => 0,
                'redirect_url' => '',
                'reference_split_the_bill' => [
                                
                ],
                'require_address' => '',
                'scheduled_id' => 0,
                'status' => '',
                'time_expiry' => '',
                'time_responded' => '',
                'updated' => '',
                'user_alias_created' => [
                                
                ],
                'user_alias_revoked' => [
                                
                ],
                'want_tip' => null
        ]
    ],
    'status' => '',
    'total_amount_inquired' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId', [
  'body' => '{
  "event_id": 0,
  "reference_split_the_bill": {
    "BillingInvoice": {
      "address": {
        "city": "",
        "country": "",
        "extra": "",
        "house_number": "",
        "is_user_address_updated": false,
        "mailbox_name": "",
        "po_box": "",
        "postal_code": "",
        "province": "",
        "street": ""
      },
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "category": "",
      "chamber_of_commerce_number": "",
      "counterparty_address": {},
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "external_url": "",
      "group": [
        {
          "instance_description": "",
          "item": [
            {
              "billing_date": "",
              "id": 0,
              "quantity": 0,
              "total_vat_exclusive": {
                "currency": "",
                "value": ""
              },
              "total_vat_inclusive": {},
              "type_description": "",
              "type_description_translated": "",
              "unit_vat_exclusive": {},
              "unit_vat_inclusive": {},
              "vat": 0
            }
          ],
          "product_vat_exclusive": {},
          "product_vat_inclusive": {},
          "type": "",
          "type_description": "",
          "type_description_translated": ""
        }
      ],
      "id": 0,
      "invoice_date": "",
      "invoice_number": "",
      "request_reference_split_the_bill": [
        {
          "id": 0,
          "type": ""
        }
      ],
      "status": "",
      "total_vat": {},
      "total_vat_exclusive": {},
      "total_vat_inclusive": {},
      "updated": "",
      "vat_number": ""
    },
    "DraftPayment": {
      "entries": [
        {
          "alias": {},
          "amount": {},
          "attachment": [
            {
              "id": 0,
              "monetary_account_id": 0
            }
          ],
          "counterparty_alias": {},
          "description": "",
          "id": 0,
          "merchant_reference": "",
          "type": ""
        }
      ],
      "number_of_required_accepts": 0,
      "previous_updated_timestamp": "",
      "schedule": {
        "object": {
          "Payment": {
            "address_billing": {},
            "address_shipping": {},
            "alias": {},
            "allow_bunqto": false,
            "amount": {},
            "attachment": [
              {}
            ],
            "balance_after_mutation": {},
            "batch_id": 0,
            "bunqto_expiry": "",
            "bunqto_share_url": "",
            "bunqto_status": "",
            "bunqto_sub_status": "",
            "bunqto_time_responded": "",
            "counterparty_alias": {},
            "created": "",
            "description": "",
            "geolocation": {
              "altitude": 0,
              "latitude": 0,
              "longitude": 0,
              "radius": 0
            },
            "id": 0,
            "merchant_reference": "",
            "monetary_account_id": 0,
            "payment_auto_allocate_instance": {
              "created": "",
              "error_message": [],
              "id": 0,
              "payment_auto_allocate_id": 0,
              "payment_batch": {
                "payments": {
                  "Payment": []
                }
              },
              "payment_id": 0,
              "status": "",
              "updated": ""
            },
            "request_reference_split_the_bill": [
              {}
            ],
            "scheduled_id": 0,
            "sub_type": "",
            "type": "",
            "updated": ""
          },
          "PaymentBatch": {}
        },
        "recurrence_size": 0,
        "recurrence_unit": "",
        "status": "",
        "time_end": "",
        "time_start": ""
      },
      "status": ""
    },
    "MasterCardAction": {
      "alias": {},
      "all_mastercard_action_refund": [
        {
          "additional_information": {
            "attachment": [
              {
                "id": 0
              }
            ],
            "category": "",
            "comment": "",
            "reason": "",
            "terms_and_conditions": ""
          },
          "alias": {},
          "amount": {},
          "attachment": [
            {}
          ],
          "category": "",
          "comment": "",
          "counterparty_alias": {},
          "created": "",
          "description": "",
          "id": 0,
          "label_card": {
            "expiry_date": "",
            "label_user": {},
            "second_line": "",
            "status": "",
            "type": "",
            "uuid": ""
          },
          "label_user_creator": {},
          "mastercard_action_id": 0,
          "reason": "",
          "reference_mastercard_action_event": [
            {
              "event_id": 0
            }
          ],
          "status": "",
          "status_description": "",
          "status_description_translated": "",
          "status_together_url": "",
          "sub_type": "",
          "terms_and_conditions": "",
          "time_refund": "",
          "type": "",
          "updated": ""
        }
      ],
      "amount_billing": {},
      "amount_converted": {},
      "amount_fee": {},
      "amount_local": {},
      "amount_original_billing": {},
      "amount_original_local": {},
      "applied_limit": "",
      "authorisation_status": "",
      "authorisation_type": "",
      "card_authorisation_id_response": "",
      "card_id": 0,
      "city": "",
      "clearing_expiry_time": "",
      "clearing_status": "",
      "counterparty_alias": {},
      "decision": "",
      "decision_description": "",
      "decision_description_translated": "",
      "decision_together_url": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "id": 0,
      "label_card": {},
      "maturity_date": "",
      "monetary_account_id": 0,
      "pan_entry_mode_user": "",
      "payment_status": "",
      "pos_card_holder_presence": "",
      "pos_card_presence": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "reservation_expiry_time": "",
      "secure_code_id": 0,
      "settlement_status": "",
      "token_status": "",
      "wallet_provider_id": ""
    },
    "Payment": {},
    "PaymentBatch": {},
    "RequestResponse": {
      "address_billing": {},
      "address_shipping": {},
      "alias": {},
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "content_type": "",
          "description": "",
          "urls": [
            {
              "type": "",
              "url": ""
            }
          ]
        }
      ],
      "counterparty_alias": {},
      "created": "",
      "credit_scheme_identifier": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "mandate_identifier": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "require_address": "",
      "status": "",
      "sub_type": "",
      "time_expiry": "",
      "time_refund_requested": "",
      "time_refunded": "",
      "time_responded": "",
      "type": "",
      "updated": "",
      "user_refund_requested": {}
    },
    "ScheduleInstance": {
      "error_message": [],
      "request_reference_split_the_bill": [
        {}
      ],
      "result_object": {
        "Payment": {},
        "PaymentBatch": {}
      },
      "scheduled_object": {},
      "state": "",
      "time_end": "",
      "time_start": ""
    },
    "TransferwisePayment": {
      "alias": {},
      "amount_source": {},
      "amount_target": {},
      "counterparty_alias": {},
      "monetary_account_id": "",
      "pay_in_reference": "",
      "quote": {
        "amount_fee": {},
        "amount_source": {},
        "amount_target": {},
        "created": "",
        "currency_source": "",
        "currency_target": "",
        "id": 0,
        "quote_id": "",
        "rate": "",
        "time_delivery_estimate": "",
        "time_expiry": "",
        "updated": ""
      },
      "rate": "",
      "recipient_id": "",
      "reference": "",
      "status": "",
      "status_transferwise": "",
      "status_transferwise_issue": "",
      "sub_status": "",
      "time_delivery_estimate": ""
    },
    "WhitelistResult": {
      "error_message": [],
      "id": 0,
      "monetary_account_paying_id": 0,
      "object": {
        "draftPayment": {},
        "id": 0,
        "requestResponse": {}
      },
      "request_reference_split_the_bill": [
        {}
      ],
      "status": "",
      "sub_status": "",
      "whitelist": {}
    }
  },
  "request_inquiries": [
    {
      "address_billing": {},
      "address_shipping": {},
      "allow_amount_higher": false,
      "allow_amount_lower": false,
      "allow_bunqme": false,
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "id": 0
        }
      ],
      "batch_id": 0,
      "bunqme_share_url": "",
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "merchant_reference": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "reference_split_the_bill": {},
      "require_address": "",
      "scheduled_id": 0,
      "status": "",
      "time_expiry": "",
      "time_responded": "",
      "updated": "",
      "user_alias_created": {},
      "user_alias_revoked": {},
      "want_tip": false
    }
  ],
  "status": "",
  "total_amount_inquired": {}
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'event_id' => 0,
  'reference_split_the_bill' => [
    'BillingInvoice' => [
        'address' => [
                'city' => '',
                'country' => '',
                'extra' => '',
                'house_number' => '',
                'is_user_address_updated' => null,
                'mailbox_name' => '',
                'po_box' => '',
                'postal_code' => '',
                'province' => '',
                'street' => ''
        ],
        'alias' => [
                'avatar' => [
                                'anchor_uuid' => '',
                                'image' => [
                                                                [
                                                                                                                                'attachment_public_uuid' => '',
                                                                                                                                'content_type' => '',
                                                                                                                                'height' => 0,
                                                                                                                                'width' => 0
                                                                ]
                                ],
                                'style' => '',
                                'uuid' => ''
                ],
                'bunq_me' => [
                                'name' => '',
                                'service' => '',
                                'type' => '',
                                'value' => ''
                ],
                'country' => '',
                'display_name' => '',
                'iban' => '',
                'is_light' => null,
                'label_user' => [
                                'avatar' => [
                                                                
                                ],
                                'country' => '',
                                'display_name' => '',
                                'public_nick_name' => '',
                                'uuid' => ''
                ],
                'merchant_category_code' => '',
                'swift_account_number' => '',
                'swift_bic' => '',
                'transferwise_account_number' => '',
                'transferwise_bank_code' => ''
        ],
        'category' => '',
        'chamber_of_commerce_number' => '',
        'counterparty_address' => [
                
        ],
        'counterparty_alias' => [
                
        ],
        'created' => '',
        'description' => '',
        'external_url' => '',
        'group' => [
                [
                                'instance_description' => '',
                                'item' => [
                                                                [
                                                                                                                                'billing_date' => '',
                                                                                                                                'id' => 0,
                                                                                                                                'quantity' => 0,
                                                                                                                                'total_vat_exclusive' => [
                                                                                                                                                                                                                                                                'currency' => '',
                                                                                                                                                                                                                                                                'value' => ''
                                                                                                                                ],
                                                                                                                                'total_vat_inclusive' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'type_description' => '',
                                                                                                                                'type_description_translated' => '',
                                                                                                                                'unit_vat_exclusive' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'unit_vat_inclusive' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'vat' => 0
                                                                ]
                                ],
                                'product_vat_exclusive' => [
                                                                
                                ],
                                'product_vat_inclusive' => [
                                                                
                                ],
                                'type' => '',
                                'type_description' => '',
                                'type_description_translated' => ''
                ]
        ],
        'id' => 0,
        'invoice_date' => '',
        'invoice_number' => '',
        'request_reference_split_the_bill' => [
                [
                                'id' => 0,
                                'type' => ''
                ]
        ],
        'status' => '',
        'total_vat' => [
                
        ],
        'total_vat_exclusive' => [
                
        ],
        'total_vat_inclusive' => [
                
        ],
        'updated' => '',
        'vat_number' => ''
    ],
    'DraftPayment' => [
        'entries' => [
                [
                                'alias' => [
                                                                
                                ],
                                'amount' => [
                                                                
                                ],
                                'attachment' => [
                                                                [
                                                                                                                                'id' => 0,
                                                                                                                                'monetary_account_id' => 0
                                                                ]
                                ],
                                'counterparty_alias' => [
                                                                
                                ],
                                'description' => '',
                                'id' => 0,
                                'merchant_reference' => '',
                                'type' => ''
                ]
        ],
        'number_of_required_accepts' => 0,
        'previous_updated_timestamp' => '',
        'schedule' => [
                'object' => [
                                'Payment' => [
                                                                'address_billing' => [
                                                                                                                                
                                                                ],
                                                                'address_shipping' => [
                                                                                                                                
                                                                ],
                                                                'alias' => [
                                                                                                                                
                                                                ],
                                                                'allow_bunqto' => null,
                                                                'amount' => [
                                                                                                                                
                                                                ],
                                                                'attachment' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'balance_after_mutation' => [
                                                                                                                                
                                                                ],
                                                                'batch_id' => 0,
                                                                'bunqto_expiry' => '',
                                                                'bunqto_share_url' => '',
                                                                'bunqto_status' => '',
                                                                'bunqto_sub_status' => '',
                                                                'bunqto_time_responded' => '',
                                                                'counterparty_alias' => [
                                                                                                                                
                                                                ],
                                                                'created' => '',
                                                                'description' => '',
                                                                'geolocation' => [
                                                                                                                                'altitude' => 0,
                                                                                                                                'latitude' => 0,
                                                                                                                                'longitude' => 0,
                                                                                                                                'radius' => 0
                                                                ],
                                                                'id' => 0,
                                                                'merchant_reference' => '',
                                                                'monetary_account_id' => 0,
                                                                'payment_auto_allocate_instance' => [
                                                                                                                                'created' => '',
                                                                                                                                'error_message' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'id' => 0,
                                                                                                                                'payment_auto_allocate_id' => 0,
                                                                                                                                'payment_batch' => [
                                                                                                                                                                                                                                                                'payments' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'Payment' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'payment_id' => 0,
                                                                                                                                'status' => '',
                                                                                                                                'updated' => ''
                                                                ],
                                                                'request_reference_split_the_bill' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'scheduled_id' => 0,
                                                                'sub_type' => '',
                                                                'type' => '',
                                                                'updated' => ''
                                ],
                                'PaymentBatch' => [
                                                                
                                ]
                ],
                'recurrence_size' => 0,
                'recurrence_unit' => '',
                'status' => '',
                'time_end' => '',
                'time_start' => ''
        ],
        'status' => ''
    ],
    'MasterCardAction' => [
        'alias' => [
                
        ],
        'all_mastercard_action_refund' => [
                [
                                'additional_information' => [
                                                                'attachment' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'id' => 0
                                                                                                                                ]
                                                                ],
                                                                'category' => '',
                                                                'comment' => '',
                                                                'reason' => '',
                                                                'terms_and_conditions' => ''
                                ],
                                'alias' => [
                                                                
                                ],
                                'amount' => [
                                                                
                                ],
                                'attachment' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'category' => '',
                                'comment' => '',
                                'counterparty_alias' => [
                                                                
                                ],
                                'created' => '',
                                'description' => '',
                                'id' => 0,
                                'label_card' => [
                                                                'expiry_date' => '',
                                                                'label_user' => [
                                                                                                                                
                                                                ],
                                                                'second_line' => '',
                                                                'status' => '',
                                                                'type' => '',
                                                                'uuid' => ''
                                ],
                                'label_user_creator' => [
                                                                
                                ],
                                'mastercard_action_id' => 0,
                                'reason' => '',
                                'reference_mastercard_action_event' => [
                                                                [
                                                                                                                                'event_id' => 0
                                                                ]
                                ],
                                'status' => '',
                                'status_description' => '',
                                'status_description_translated' => '',
                                'status_together_url' => '',
                                'sub_type' => '',
                                'terms_and_conditions' => '',
                                'time_refund' => '',
                                'type' => '',
                                'updated' => ''
                ]
        ],
        'amount_billing' => [
                
        ],
        'amount_converted' => [
                
        ],
        'amount_fee' => [
                
        ],
        'amount_local' => [
                
        ],
        'amount_original_billing' => [
                
        ],
        'amount_original_local' => [
                
        ],
        'applied_limit' => '',
        'authorisation_status' => '',
        'authorisation_type' => '',
        'card_authorisation_id_response' => '',
        'card_id' => 0,
        'city' => '',
        'clearing_expiry_time' => '',
        'clearing_status' => '',
        'counterparty_alias' => [
                
        ],
        'decision' => '',
        'decision_description' => '',
        'decision_description_translated' => '',
        'decision_together_url' => '',
        'description' => '',
        'eligible_whitelist_id' => 0,
        'id' => 0,
        'label_card' => [
                
        ],
        'maturity_date' => '',
        'monetary_account_id' => 0,
        'pan_entry_mode_user' => '',
        'payment_status' => '',
        'pos_card_holder_presence' => '',
        'pos_card_presence' => '',
        'request_reference_split_the_bill' => [
                [
                                
                ]
        ],
        'reservation_expiry_time' => '',
        'secure_code_id' => 0,
        'settlement_status' => '',
        'token_status' => '',
        'wallet_provider_id' => ''
    ],
    'Payment' => [
        
    ],
    'PaymentBatch' => [
        
    ],
    'RequestResponse' => [
        'address_billing' => [
                
        ],
        'address_shipping' => [
                
        ],
        'alias' => [
                
        ],
        'amount_inquired' => [
                
        ],
        'amount_responded' => [
                
        ],
        'attachment' => [
                [
                                'content_type' => '',
                                'description' => '',
                                'urls' => [
                                                                [
                                                                                                                                'type' => '',
                                                                                                                                'url' => ''
                                                                ]
                                ]
                ]
        ],
        'counterparty_alias' => [
                
        ],
        'created' => '',
        'credit_scheme_identifier' => '',
        'description' => '',
        'eligible_whitelist_id' => 0,
        'event_id' => 0,
        'geolocation' => [
                
        ],
        'id' => 0,
        'mandate_identifier' => '',
        'minimum_age' => 0,
        'monetary_account_id' => 0,
        'redirect_url' => '',
        'request_reference_split_the_bill' => [
                [
                                
                ]
        ],
        'require_address' => '',
        'status' => '',
        'sub_type' => '',
        'time_expiry' => '',
        'time_refund_requested' => '',
        'time_refunded' => '',
        'time_responded' => '',
        'type' => '',
        'updated' => '',
        'user_refund_requested' => [
                
        ]
    ],
    'ScheduleInstance' => [
        'error_message' => [
                
        ],
        'request_reference_split_the_bill' => [
                [
                                
                ]
        ],
        'result_object' => [
                'Payment' => [
                                
                ],
                'PaymentBatch' => [
                                
                ]
        ],
        'scheduled_object' => [
                
        ],
        'state' => '',
        'time_end' => '',
        'time_start' => ''
    ],
    'TransferwisePayment' => [
        'alias' => [
                
        ],
        'amount_source' => [
                
        ],
        'amount_target' => [
                
        ],
        'counterparty_alias' => [
                
        ],
        'monetary_account_id' => '',
        'pay_in_reference' => '',
        'quote' => [
                'amount_fee' => [
                                
                ],
                'amount_source' => [
                                
                ],
                'amount_target' => [
                                
                ],
                'created' => '',
                'currency_source' => '',
                'currency_target' => '',
                'id' => 0,
                'quote_id' => '',
                'rate' => '',
                'time_delivery_estimate' => '',
                'time_expiry' => '',
                'updated' => ''
        ],
        'rate' => '',
        'recipient_id' => '',
        'reference' => '',
        'status' => '',
        'status_transferwise' => '',
        'status_transferwise_issue' => '',
        'sub_status' => '',
        'time_delivery_estimate' => ''
    ],
    'WhitelistResult' => [
        'error_message' => [
                
        ],
        'id' => 0,
        'monetary_account_paying_id' => 0,
        'object' => [
                'draftPayment' => [
                                
                ],
                'id' => 0,
                'requestResponse' => [
                                
                ]
        ],
        'request_reference_split_the_bill' => [
                [
                                
                ]
        ],
        'status' => '',
        'sub_status' => '',
        'whitelist' => [
                
        ]
    ]
  ],
  'request_inquiries' => [
    [
        'address_billing' => [
                
        ],
        'address_shipping' => [
                
        ],
        'allow_amount_higher' => null,
        'allow_amount_lower' => null,
        'allow_bunqme' => null,
        'amount_inquired' => [
                
        ],
        'amount_responded' => [
                
        ],
        'attachment' => [
                [
                                'id' => 0
                ]
        ],
        'batch_id' => 0,
        'bunqme_share_url' => '',
        'counterparty_alias' => [
                
        ],
        'created' => '',
        'description' => '',
        'event_id' => 0,
        'geolocation' => [
                
        ],
        'id' => 0,
        'merchant_reference' => '',
        'minimum_age' => 0,
        'monetary_account_id' => 0,
        'redirect_url' => '',
        'reference_split_the_bill' => [
                
        ],
        'require_address' => '',
        'scheduled_id' => 0,
        'status' => '',
        'time_expiry' => '',
        'time_responded' => '',
        'updated' => '',
        'user_alias_created' => [
                
        ],
        'user_alias_revoked' => [
                
        ],
        'want_tip' => null
    ]
  ],
  'status' => '',
  'total_amount_inquired' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'event_id' => 0,
  'reference_split_the_bill' => [
    'BillingInvoice' => [
        'address' => [
                'city' => '',
                'country' => '',
                'extra' => '',
                'house_number' => '',
                'is_user_address_updated' => null,
                'mailbox_name' => '',
                'po_box' => '',
                'postal_code' => '',
                'province' => '',
                'street' => ''
        ],
        'alias' => [
                'avatar' => [
                                'anchor_uuid' => '',
                                'image' => [
                                                                [
                                                                                                                                'attachment_public_uuid' => '',
                                                                                                                                'content_type' => '',
                                                                                                                                'height' => 0,
                                                                                                                                'width' => 0
                                                                ]
                                ],
                                'style' => '',
                                'uuid' => ''
                ],
                'bunq_me' => [
                                'name' => '',
                                'service' => '',
                                'type' => '',
                                'value' => ''
                ],
                'country' => '',
                'display_name' => '',
                'iban' => '',
                'is_light' => null,
                'label_user' => [
                                'avatar' => [
                                                                
                                ],
                                'country' => '',
                                'display_name' => '',
                                'public_nick_name' => '',
                                'uuid' => ''
                ],
                'merchant_category_code' => '',
                'swift_account_number' => '',
                'swift_bic' => '',
                'transferwise_account_number' => '',
                'transferwise_bank_code' => ''
        ],
        'category' => '',
        'chamber_of_commerce_number' => '',
        'counterparty_address' => [
                
        ],
        'counterparty_alias' => [
                
        ],
        'created' => '',
        'description' => '',
        'external_url' => '',
        'group' => [
                [
                                'instance_description' => '',
                                'item' => [
                                                                [
                                                                                                                                'billing_date' => '',
                                                                                                                                'id' => 0,
                                                                                                                                'quantity' => 0,
                                                                                                                                'total_vat_exclusive' => [
                                                                                                                                                                                                                                                                'currency' => '',
                                                                                                                                                                                                                                                                'value' => ''
                                                                                                                                ],
                                                                                                                                'total_vat_inclusive' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'type_description' => '',
                                                                                                                                'type_description_translated' => '',
                                                                                                                                'unit_vat_exclusive' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'unit_vat_inclusive' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'vat' => 0
                                                                ]
                                ],
                                'product_vat_exclusive' => [
                                                                
                                ],
                                'product_vat_inclusive' => [
                                                                
                                ],
                                'type' => '',
                                'type_description' => '',
                                'type_description_translated' => ''
                ]
        ],
        'id' => 0,
        'invoice_date' => '',
        'invoice_number' => '',
        'request_reference_split_the_bill' => [
                [
                                'id' => 0,
                                'type' => ''
                ]
        ],
        'status' => '',
        'total_vat' => [
                
        ],
        'total_vat_exclusive' => [
                
        ],
        'total_vat_inclusive' => [
                
        ],
        'updated' => '',
        'vat_number' => ''
    ],
    'DraftPayment' => [
        'entries' => [
                [
                                'alias' => [
                                                                
                                ],
                                'amount' => [
                                                                
                                ],
                                'attachment' => [
                                                                [
                                                                                                                                'id' => 0,
                                                                                                                                'monetary_account_id' => 0
                                                                ]
                                ],
                                'counterparty_alias' => [
                                                                
                                ],
                                'description' => '',
                                'id' => 0,
                                'merchant_reference' => '',
                                'type' => ''
                ]
        ],
        'number_of_required_accepts' => 0,
        'previous_updated_timestamp' => '',
        'schedule' => [
                'object' => [
                                'Payment' => [
                                                                'address_billing' => [
                                                                                                                                
                                                                ],
                                                                'address_shipping' => [
                                                                                                                                
                                                                ],
                                                                'alias' => [
                                                                                                                                
                                                                ],
                                                                'allow_bunqto' => null,
                                                                'amount' => [
                                                                                                                                
                                                                ],
                                                                'attachment' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'balance_after_mutation' => [
                                                                                                                                
                                                                ],
                                                                'batch_id' => 0,
                                                                'bunqto_expiry' => '',
                                                                'bunqto_share_url' => '',
                                                                'bunqto_status' => '',
                                                                'bunqto_sub_status' => '',
                                                                'bunqto_time_responded' => '',
                                                                'counterparty_alias' => [
                                                                                                                                
                                                                ],
                                                                'created' => '',
                                                                'description' => '',
                                                                'geolocation' => [
                                                                                                                                'altitude' => 0,
                                                                                                                                'latitude' => 0,
                                                                                                                                'longitude' => 0,
                                                                                                                                'radius' => 0
                                                                ],
                                                                'id' => 0,
                                                                'merchant_reference' => '',
                                                                'monetary_account_id' => 0,
                                                                'payment_auto_allocate_instance' => [
                                                                                                                                'created' => '',
                                                                                                                                'error_message' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'id' => 0,
                                                                                                                                'payment_auto_allocate_id' => 0,
                                                                                                                                'payment_batch' => [
                                                                                                                                                                                                                                                                'payments' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'Payment' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'payment_id' => 0,
                                                                                                                                'status' => '',
                                                                                                                                'updated' => ''
                                                                ],
                                                                'request_reference_split_the_bill' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'scheduled_id' => 0,
                                                                'sub_type' => '',
                                                                'type' => '',
                                                                'updated' => ''
                                ],
                                'PaymentBatch' => [
                                                                
                                ]
                ],
                'recurrence_size' => 0,
                'recurrence_unit' => '',
                'status' => '',
                'time_end' => '',
                'time_start' => ''
        ],
        'status' => ''
    ],
    'MasterCardAction' => [
        'alias' => [
                
        ],
        'all_mastercard_action_refund' => [
                [
                                'additional_information' => [
                                                                'attachment' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'id' => 0
                                                                                                                                ]
                                                                ],
                                                                'category' => '',
                                                                'comment' => '',
                                                                'reason' => '',
                                                                'terms_and_conditions' => ''
                                ],
                                'alias' => [
                                                                
                                ],
                                'amount' => [
                                                                
                                ],
                                'attachment' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'category' => '',
                                'comment' => '',
                                'counterparty_alias' => [
                                                                
                                ],
                                'created' => '',
                                'description' => '',
                                'id' => 0,
                                'label_card' => [
                                                                'expiry_date' => '',
                                                                'label_user' => [
                                                                                                                                
                                                                ],
                                                                'second_line' => '',
                                                                'status' => '',
                                                                'type' => '',
                                                                'uuid' => ''
                                ],
                                'label_user_creator' => [
                                                                
                                ],
                                'mastercard_action_id' => 0,
                                'reason' => '',
                                'reference_mastercard_action_event' => [
                                                                [
                                                                                                                                'event_id' => 0
                                                                ]
                                ],
                                'status' => '',
                                'status_description' => '',
                                'status_description_translated' => '',
                                'status_together_url' => '',
                                'sub_type' => '',
                                'terms_and_conditions' => '',
                                'time_refund' => '',
                                'type' => '',
                                'updated' => ''
                ]
        ],
        'amount_billing' => [
                
        ],
        'amount_converted' => [
                
        ],
        'amount_fee' => [
                
        ],
        'amount_local' => [
                
        ],
        'amount_original_billing' => [
                
        ],
        'amount_original_local' => [
                
        ],
        'applied_limit' => '',
        'authorisation_status' => '',
        'authorisation_type' => '',
        'card_authorisation_id_response' => '',
        'card_id' => 0,
        'city' => '',
        'clearing_expiry_time' => '',
        'clearing_status' => '',
        'counterparty_alias' => [
                
        ],
        'decision' => '',
        'decision_description' => '',
        'decision_description_translated' => '',
        'decision_together_url' => '',
        'description' => '',
        'eligible_whitelist_id' => 0,
        'id' => 0,
        'label_card' => [
                
        ],
        'maturity_date' => '',
        'monetary_account_id' => 0,
        'pan_entry_mode_user' => '',
        'payment_status' => '',
        'pos_card_holder_presence' => '',
        'pos_card_presence' => '',
        'request_reference_split_the_bill' => [
                [
                                
                ]
        ],
        'reservation_expiry_time' => '',
        'secure_code_id' => 0,
        'settlement_status' => '',
        'token_status' => '',
        'wallet_provider_id' => ''
    ],
    'Payment' => [
        
    ],
    'PaymentBatch' => [
        
    ],
    'RequestResponse' => [
        'address_billing' => [
                
        ],
        'address_shipping' => [
                
        ],
        'alias' => [
                
        ],
        'amount_inquired' => [
                
        ],
        'amount_responded' => [
                
        ],
        'attachment' => [
                [
                                'content_type' => '',
                                'description' => '',
                                'urls' => [
                                                                [
                                                                                                                                'type' => '',
                                                                                                                                'url' => ''
                                                                ]
                                ]
                ]
        ],
        'counterparty_alias' => [
                
        ],
        'created' => '',
        'credit_scheme_identifier' => '',
        'description' => '',
        'eligible_whitelist_id' => 0,
        'event_id' => 0,
        'geolocation' => [
                
        ],
        'id' => 0,
        'mandate_identifier' => '',
        'minimum_age' => 0,
        'monetary_account_id' => 0,
        'redirect_url' => '',
        'request_reference_split_the_bill' => [
                [
                                
                ]
        ],
        'require_address' => '',
        'status' => '',
        'sub_type' => '',
        'time_expiry' => '',
        'time_refund_requested' => '',
        'time_refunded' => '',
        'time_responded' => '',
        'type' => '',
        'updated' => '',
        'user_refund_requested' => [
                
        ]
    ],
    'ScheduleInstance' => [
        'error_message' => [
                
        ],
        'request_reference_split_the_bill' => [
                [
                                
                ]
        ],
        'result_object' => [
                'Payment' => [
                                
                ],
                'PaymentBatch' => [
                                
                ]
        ],
        'scheduled_object' => [
                
        ],
        'state' => '',
        'time_end' => '',
        'time_start' => ''
    ],
    'TransferwisePayment' => [
        'alias' => [
                
        ],
        'amount_source' => [
                
        ],
        'amount_target' => [
                
        ],
        'counterparty_alias' => [
                
        ],
        'monetary_account_id' => '',
        'pay_in_reference' => '',
        'quote' => [
                'amount_fee' => [
                                
                ],
                'amount_source' => [
                                
                ],
                'amount_target' => [
                                
                ],
                'created' => '',
                'currency_source' => '',
                'currency_target' => '',
                'id' => 0,
                'quote_id' => '',
                'rate' => '',
                'time_delivery_estimate' => '',
                'time_expiry' => '',
                'updated' => ''
        ],
        'rate' => '',
        'recipient_id' => '',
        'reference' => '',
        'status' => '',
        'status_transferwise' => '',
        'status_transferwise_issue' => '',
        'sub_status' => '',
        'time_delivery_estimate' => ''
    ],
    'WhitelistResult' => [
        'error_message' => [
                
        ],
        'id' => 0,
        'monetary_account_paying_id' => 0,
        'object' => [
                'draftPayment' => [
                                
                ],
                'id' => 0,
                'requestResponse' => [
                                
                ]
        ],
        'request_reference_split_the_bill' => [
                [
                                
                ]
        ],
        'status' => '',
        'sub_status' => '',
        'whitelist' => [
                
        ]
    ]
  ],
  'request_inquiries' => [
    [
        'address_billing' => [
                
        ],
        'address_shipping' => [
                
        ],
        'allow_amount_higher' => null,
        'allow_amount_lower' => null,
        'allow_bunqme' => null,
        'amount_inquired' => [
                
        ],
        'amount_responded' => [
                
        ],
        'attachment' => [
                [
                                'id' => 0
                ]
        ],
        'batch_id' => 0,
        'bunqme_share_url' => '',
        'counterparty_alias' => [
                
        ],
        'created' => '',
        'description' => '',
        'event_id' => 0,
        'geolocation' => [
                
        ],
        'id' => 0,
        'merchant_reference' => '',
        'minimum_age' => 0,
        'monetary_account_id' => 0,
        'redirect_url' => '',
        'reference_split_the_bill' => [
                
        ],
        'require_address' => '',
        'scheduled_id' => 0,
        'status' => '',
        'time_expiry' => '',
        'time_responded' => '',
        'updated' => '',
        'user_alias_created' => [
                
        ],
        'user_alias_revoked' => [
                
        ],
        'want_tip' => null
    ]
  ],
  'status' => '',
  'total_amount_inquired' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "event_id": 0,
  "reference_split_the_bill": {
    "BillingInvoice": {
      "address": {
        "city": "",
        "country": "",
        "extra": "",
        "house_number": "",
        "is_user_address_updated": false,
        "mailbox_name": "",
        "po_box": "",
        "postal_code": "",
        "province": "",
        "street": ""
      },
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "category": "",
      "chamber_of_commerce_number": "",
      "counterparty_address": {},
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "external_url": "",
      "group": [
        {
          "instance_description": "",
          "item": [
            {
              "billing_date": "",
              "id": 0,
              "quantity": 0,
              "total_vat_exclusive": {
                "currency": "",
                "value": ""
              },
              "total_vat_inclusive": {},
              "type_description": "",
              "type_description_translated": "",
              "unit_vat_exclusive": {},
              "unit_vat_inclusive": {},
              "vat": 0
            }
          ],
          "product_vat_exclusive": {},
          "product_vat_inclusive": {},
          "type": "",
          "type_description": "",
          "type_description_translated": ""
        }
      ],
      "id": 0,
      "invoice_date": "",
      "invoice_number": "",
      "request_reference_split_the_bill": [
        {
          "id": 0,
          "type": ""
        }
      ],
      "status": "",
      "total_vat": {},
      "total_vat_exclusive": {},
      "total_vat_inclusive": {},
      "updated": "",
      "vat_number": ""
    },
    "DraftPayment": {
      "entries": [
        {
          "alias": {},
          "amount": {},
          "attachment": [
            {
              "id": 0,
              "monetary_account_id": 0
            }
          ],
          "counterparty_alias": {},
          "description": "",
          "id": 0,
          "merchant_reference": "",
          "type": ""
        }
      ],
      "number_of_required_accepts": 0,
      "previous_updated_timestamp": "",
      "schedule": {
        "object": {
          "Payment": {
            "address_billing": {},
            "address_shipping": {},
            "alias": {},
            "allow_bunqto": false,
            "amount": {},
            "attachment": [
              {}
            ],
            "balance_after_mutation": {},
            "batch_id": 0,
            "bunqto_expiry": "",
            "bunqto_share_url": "",
            "bunqto_status": "",
            "bunqto_sub_status": "",
            "bunqto_time_responded": "",
            "counterparty_alias": {},
            "created": "",
            "description": "",
            "geolocation": {
              "altitude": 0,
              "latitude": 0,
              "longitude": 0,
              "radius": 0
            },
            "id": 0,
            "merchant_reference": "",
            "monetary_account_id": 0,
            "payment_auto_allocate_instance": {
              "created": "",
              "error_message": [],
              "id": 0,
              "payment_auto_allocate_id": 0,
              "payment_batch": {
                "payments": {
                  "Payment": []
                }
              },
              "payment_id": 0,
              "status": "",
              "updated": ""
            },
            "request_reference_split_the_bill": [
              {}
            ],
            "scheduled_id": 0,
            "sub_type": "",
            "type": "",
            "updated": ""
          },
          "PaymentBatch": {}
        },
        "recurrence_size": 0,
        "recurrence_unit": "",
        "status": "",
        "time_end": "",
        "time_start": ""
      },
      "status": ""
    },
    "MasterCardAction": {
      "alias": {},
      "all_mastercard_action_refund": [
        {
          "additional_information": {
            "attachment": [
              {
                "id": 0
              }
            ],
            "category": "",
            "comment": "",
            "reason": "",
            "terms_and_conditions": ""
          },
          "alias": {},
          "amount": {},
          "attachment": [
            {}
          ],
          "category": "",
          "comment": "",
          "counterparty_alias": {},
          "created": "",
          "description": "",
          "id": 0,
          "label_card": {
            "expiry_date": "",
            "label_user": {},
            "second_line": "",
            "status": "",
            "type": "",
            "uuid": ""
          },
          "label_user_creator": {},
          "mastercard_action_id": 0,
          "reason": "",
          "reference_mastercard_action_event": [
            {
              "event_id": 0
            }
          ],
          "status": "",
          "status_description": "",
          "status_description_translated": "",
          "status_together_url": "",
          "sub_type": "",
          "terms_and_conditions": "",
          "time_refund": "",
          "type": "",
          "updated": ""
        }
      ],
      "amount_billing": {},
      "amount_converted": {},
      "amount_fee": {},
      "amount_local": {},
      "amount_original_billing": {},
      "amount_original_local": {},
      "applied_limit": "",
      "authorisation_status": "",
      "authorisation_type": "",
      "card_authorisation_id_response": "",
      "card_id": 0,
      "city": "",
      "clearing_expiry_time": "",
      "clearing_status": "",
      "counterparty_alias": {},
      "decision": "",
      "decision_description": "",
      "decision_description_translated": "",
      "decision_together_url": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "id": 0,
      "label_card": {},
      "maturity_date": "",
      "monetary_account_id": 0,
      "pan_entry_mode_user": "",
      "payment_status": "",
      "pos_card_holder_presence": "",
      "pos_card_presence": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "reservation_expiry_time": "",
      "secure_code_id": 0,
      "settlement_status": "",
      "token_status": "",
      "wallet_provider_id": ""
    },
    "Payment": {},
    "PaymentBatch": {},
    "RequestResponse": {
      "address_billing": {},
      "address_shipping": {},
      "alias": {},
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "content_type": "",
          "description": "",
          "urls": [
            {
              "type": "",
              "url": ""
            }
          ]
        }
      ],
      "counterparty_alias": {},
      "created": "",
      "credit_scheme_identifier": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "mandate_identifier": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "require_address": "",
      "status": "",
      "sub_type": "",
      "time_expiry": "",
      "time_refund_requested": "",
      "time_refunded": "",
      "time_responded": "",
      "type": "",
      "updated": "",
      "user_refund_requested": {}
    },
    "ScheduleInstance": {
      "error_message": [],
      "request_reference_split_the_bill": [
        {}
      ],
      "result_object": {
        "Payment": {},
        "PaymentBatch": {}
      },
      "scheduled_object": {},
      "state": "",
      "time_end": "",
      "time_start": ""
    },
    "TransferwisePayment": {
      "alias": {},
      "amount_source": {},
      "amount_target": {},
      "counterparty_alias": {},
      "monetary_account_id": "",
      "pay_in_reference": "",
      "quote": {
        "amount_fee": {},
        "amount_source": {},
        "amount_target": {},
        "created": "",
        "currency_source": "",
        "currency_target": "",
        "id": 0,
        "quote_id": "",
        "rate": "",
        "time_delivery_estimate": "",
        "time_expiry": "",
        "updated": ""
      },
      "rate": "",
      "recipient_id": "",
      "reference": "",
      "status": "",
      "status_transferwise": "",
      "status_transferwise_issue": "",
      "sub_status": "",
      "time_delivery_estimate": ""
    },
    "WhitelistResult": {
      "error_message": [],
      "id": 0,
      "monetary_account_paying_id": 0,
      "object": {
        "draftPayment": {},
        "id": 0,
        "requestResponse": {}
      },
      "request_reference_split_the_bill": [
        {}
      ],
      "status": "",
      "sub_status": "",
      "whitelist": {}
    }
  },
  "request_inquiries": [
    {
      "address_billing": {},
      "address_shipping": {},
      "allow_amount_higher": false,
      "allow_amount_lower": false,
      "allow_bunqme": false,
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "id": 0
        }
      ],
      "batch_id": 0,
      "bunqme_share_url": "",
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "merchant_reference": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "reference_split_the_bill": {},
      "require_address": "",
      "scheduled_id": 0,
      "status": "",
      "time_expiry": "",
      "time_responded": "",
      "updated": "",
      "user_alias_created": {},
      "user_alias_revoked": {},
      "want_tip": false
    }
  ],
  "status": "",
  "total_amount_inquired": {}
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "event_id": 0,
  "reference_split_the_bill": {
    "BillingInvoice": {
      "address": {
        "city": "",
        "country": "",
        "extra": "",
        "house_number": "",
        "is_user_address_updated": false,
        "mailbox_name": "",
        "po_box": "",
        "postal_code": "",
        "province": "",
        "street": ""
      },
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "category": "",
      "chamber_of_commerce_number": "",
      "counterparty_address": {},
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "external_url": "",
      "group": [
        {
          "instance_description": "",
          "item": [
            {
              "billing_date": "",
              "id": 0,
              "quantity": 0,
              "total_vat_exclusive": {
                "currency": "",
                "value": ""
              },
              "total_vat_inclusive": {},
              "type_description": "",
              "type_description_translated": "",
              "unit_vat_exclusive": {},
              "unit_vat_inclusive": {},
              "vat": 0
            }
          ],
          "product_vat_exclusive": {},
          "product_vat_inclusive": {},
          "type": "",
          "type_description": "",
          "type_description_translated": ""
        }
      ],
      "id": 0,
      "invoice_date": "",
      "invoice_number": "",
      "request_reference_split_the_bill": [
        {
          "id": 0,
          "type": ""
        }
      ],
      "status": "",
      "total_vat": {},
      "total_vat_exclusive": {},
      "total_vat_inclusive": {},
      "updated": "",
      "vat_number": ""
    },
    "DraftPayment": {
      "entries": [
        {
          "alias": {},
          "amount": {},
          "attachment": [
            {
              "id": 0,
              "monetary_account_id": 0
            }
          ],
          "counterparty_alias": {},
          "description": "",
          "id": 0,
          "merchant_reference": "",
          "type": ""
        }
      ],
      "number_of_required_accepts": 0,
      "previous_updated_timestamp": "",
      "schedule": {
        "object": {
          "Payment": {
            "address_billing": {},
            "address_shipping": {},
            "alias": {},
            "allow_bunqto": false,
            "amount": {},
            "attachment": [
              {}
            ],
            "balance_after_mutation": {},
            "batch_id": 0,
            "bunqto_expiry": "",
            "bunqto_share_url": "",
            "bunqto_status": "",
            "bunqto_sub_status": "",
            "bunqto_time_responded": "",
            "counterparty_alias": {},
            "created": "",
            "description": "",
            "geolocation": {
              "altitude": 0,
              "latitude": 0,
              "longitude": 0,
              "radius": 0
            },
            "id": 0,
            "merchant_reference": "",
            "monetary_account_id": 0,
            "payment_auto_allocate_instance": {
              "created": "",
              "error_message": [],
              "id": 0,
              "payment_auto_allocate_id": 0,
              "payment_batch": {
                "payments": {
                  "Payment": []
                }
              },
              "payment_id": 0,
              "status": "",
              "updated": ""
            },
            "request_reference_split_the_bill": [
              {}
            ],
            "scheduled_id": 0,
            "sub_type": "",
            "type": "",
            "updated": ""
          },
          "PaymentBatch": {}
        },
        "recurrence_size": 0,
        "recurrence_unit": "",
        "status": "",
        "time_end": "",
        "time_start": ""
      },
      "status": ""
    },
    "MasterCardAction": {
      "alias": {},
      "all_mastercard_action_refund": [
        {
          "additional_information": {
            "attachment": [
              {
                "id": 0
              }
            ],
            "category": "",
            "comment": "",
            "reason": "",
            "terms_and_conditions": ""
          },
          "alias": {},
          "amount": {},
          "attachment": [
            {}
          ],
          "category": "",
          "comment": "",
          "counterparty_alias": {},
          "created": "",
          "description": "",
          "id": 0,
          "label_card": {
            "expiry_date": "",
            "label_user": {},
            "second_line": "",
            "status": "",
            "type": "",
            "uuid": ""
          },
          "label_user_creator": {},
          "mastercard_action_id": 0,
          "reason": "",
          "reference_mastercard_action_event": [
            {
              "event_id": 0
            }
          ],
          "status": "",
          "status_description": "",
          "status_description_translated": "",
          "status_together_url": "",
          "sub_type": "",
          "terms_and_conditions": "",
          "time_refund": "",
          "type": "",
          "updated": ""
        }
      ],
      "amount_billing": {},
      "amount_converted": {},
      "amount_fee": {},
      "amount_local": {},
      "amount_original_billing": {},
      "amount_original_local": {},
      "applied_limit": "",
      "authorisation_status": "",
      "authorisation_type": "",
      "card_authorisation_id_response": "",
      "card_id": 0,
      "city": "",
      "clearing_expiry_time": "",
      "clearing_status": "",
      "counterparty_alias": {},
      "decision": "",
      "decision_description": "",
      "decision_description_translated": "",
      "decision_together_url": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "id": 0,
      "label_card": {},
      "maturity_date": "",
      "monetary_account_id": 0,
      "pan_entry_mode_user": "",
      "payment_status": "",
      "pos_card_holder_presence": "",
      "pos_card_presence": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "reservation_expiry_time": "",
      "secure_code_id": 0,
      "settlement_status": "",
      "token_status": "",
      "wallet_provider_id": ""
    },
    "Payment": {},
    "PaymentBatch": {},
    "RequestResponse": {
      "address_billing": {},
      "address_shipping": {},
      "alias": {},
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "content_type": "",
          "description": "",
          "urls": [
            {
              "type": "",
              "url": ""
            }
          ]
        }
      ],
      "counterparty_alias": {},
      "created": "",
      "credit_scheme_identifier": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "mandate_identifier": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "require_address": "",
      "status": "",
      "sub_type": "",
      "time_expiry": "",
      "time_refund_requested": "",
      "time_refunded": "",
      "time_responded": "",
      "type": "",
      "updated": "",
      "user_refund_requested": {}
    },
    "ScheduleInstance": {
      "error_message": [],
      "request_reference_split_the_bill": [
        {}
      ],
      "result_object": {
        "Payment": {},
        "PaymentBatch": {}
      },
      "scheduled_object": {},
      "state": "",
      "time_end": "",
      "time_start": ""
    },
    "TransferwisePayment": {
      "alias": {},
      "amount_source": {},
      "amount_target": {},
      "counterparty_alias": {},
      "monetary_account_id": "",
      "pay_in_reference": "",
      "quote": {
        "amount_fee": {},
        "amount_source": {},
        "amount_target": {},
        "created": "",
        "currency_source": "",
        "currency_target": "",
        "id": 0,
        "quote_id": "",
        "rate": "",
        "time_delivery_estimate": "",
        "time_expiry": "",
        "updated": ""
      },
      "rate": "",
      "recipient_id": "",
      "reference": "",
      "status": "",
      "status_transferwise": "",
      "status_transferwise_issue": "",
      "sub_status": "",
      "time_delivery_estimate": ""
    },
    "WhitelistResult": {
      "error_message": [],
      "id": 0,
      "monetary_account_paying_id": 0,
      "object": {
        "draftPayment": {},
        "id": 0,
        "requestResponse": {}
      },
      "request_reference_split_the_bill": [
        {}
      ],
      "status": "",
      "sub_status": "",
      "whitelist": {}
    }
  },
  "request_inquiries": [
    {
      "address_billing": {},
      "address_shipping": {},
      "allow_amount_higher": false,
      "allow_amount_lower": false,
      "allow_bunqme": false,
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "id": 0
        }
      ],
      "batch_id": 0,
      "bunqme_share_url": "",
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "merchant_reference": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "reference_split_the_bill": {},
      "require_address": "",
      "scheduled_id": 0,
      "status": "",
      "time_expiry": "",
      "time_responded": "",
      "updated": "",
      "user_alias_created": {},
      "user_alias_revoked": {},
      "want_tip": false
    }
  ],
  "status": "",
  "total_amount_inquired": {}
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"event_id\": 0,\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {\n                \"currency\": \"\",\n                \"value\": \"\"\n              },\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {\n              \"altitude\": 0,\n              \"latitude\": 0,\n              \"longitude\": 0,\n              \"radius\": 0\n            },\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"request_inquiries\": [\n    {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"allow_amount_higher\": false,\n      \"allow_amount_lower\": false,\n      \"allow_bunqme\": false,\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"id\": 0\n        }\n      ],\n      \"batch_id\": 0,\n      \"bunqme_share_url\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"reference_split_the_bill\": {},\n      \"require_address\": \"\",\n      \"scheduled_id\": 0,\n      \"status\": \"\",\n      \"time_expiry\": \"\",\n      \"time_responded\": \"\",\n      \"updated\": \"\",\n      \"user_alias_created\": {},\n      \"user_alias_revoked\": {},\n      \"want_tip\": false\n    }\n  ],\n  \"status\": \"\",\n  \"total_amount_inquired\": {}\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId"

payload = {
    "event_id": 0,
    "reference_split_the_bill": {
        "BillingInvoice": {
            "address": {
                "city": "",
                "country": "",
                "extra": "",
                "house_number": "",
                "is_user_address_updated": False,
                "mailbox_name": "",
                "po_box": "",
                "postal_code": "",
                "province": "",
                "street": ""
            },
            "alias": {
                "avatar": {
                    "anchor_uuid": "",
                    "image": [
                        {
                            "attachment_public_uuid": "",
                            "content_type": "",
                            "height": 0,
                            "width": 0
                        }
                    ],
                    "style": "",
                    "uuid": ""
                },
                "bunq_me": {
                    "name": "",
                    "service": "",
                    "type": "",
                    "value": ""
                },
                "country": "",
                "display_name": "",
                "iban": "",
                "is_light": False,
                "label_user": {
                    "avatar": {},
                    "country": "",
                    "display_name": "",
                    "public_nick_name": "",
                    "uuid": ""
                },
                "merchant_category_code": "",
                "swift_account_number": "",
                "swift_bic": "",
                "transferwise_account_number": "",
                "transferwise_bank_code": ""
            },
            "category": "",
            "chamber_of_commerce_number": "",
            "counterparty_address": {},
            "counterparty_alias": {},
            "created": "",
            "description": "",
            "external_url": "",
            "group": [
                {
                    "instance_description": "",
                    "item": [
                        {
                            "billing_date": "",
                            "id": 0,
                            "quantity": 0,
                            "total_vat_exclusive": {
                                "currency": "",
                                "value": ""
                            },
                            "total_vat_inclusive": {},
                            "type_description": "",
                            "type_description_translated": "",
                            "unit_vat_exclusive": {},
                            "unit_vat_inclusive": {},
                            "vat": 0
                        }
                    ],
                    "product_vat_exclusive": {},
                    "product_vat_inclusive": {},
                    "type": "",
                    "type_description": "",
                    "type_description_translated": ""
                }
            ],
            "id": 0,
            "invoice_date": "",
            "invoice_number": "",
            "request_reference_split_the_bill": [
                {
                    "id": 0,
                    "type": ""
                }
            ],
            "status": "",
            "total_vat": {},
            "total_vat_exclusive": {},
            "total_vat_inclusive": {},
            "updated": "",
            "vat_number": ""
        },
        "DraftPayment": {
            "entries": [
                {
                    "alias": {},
                    "amount": {},
                    "attachment": [
                        {
                            "id": 0,
                            "monetary_account_id": 0
                        }
                    ],
                    "counterparty_alias": {},
                    "description": "",
                    "id": 0,
                    "merchant_reference": "",
                    "type": ""
                }
            ],
            "number_of_required_accepts": 0,
            "previous_updated_timestamp": "",
            "schedule": {
                "object": {
                    "Payment": {
                        "address_billing": {},
                        "address_shipping": {},
                        "alias": {},
                        "allow_bunqto": False,
                        "amount": {},
                        "attachment": [{}],
                        "balance_after_mutation": {},
                        "batch_id": 0,
                        "bunqto_expiry": "",
                        "bunqto_share_url": "",
                        "bunqto_status": "",
                        "bunqto_sub_status": "",
                        "bunqto_time_responded": "",
                        "counterparty_alias": {},
                        "created": "",
                        "description": "",
                        "geolocation": {
                            "altitude": 0,
                            "latitude": 0,
                            "longitude": 0,
                            "radius": 0
                        },
                        "id": 0,
                        "merchant_reference": "",
                        "monetary_account_id": 0,
                        "payment_auto_allocate_instance": {
                            "created": "",
                            "error_message": [],
                            "id": 0,
                            "payment_auto_allocate_id": 0,
                            "payment_batch": { "payments": { "Payment": [] } },
                            "payment_id": 0,
                            "status": "",
                            "updated": ""
                        },
                        "request_reference_split_the_bill": [{}],
                        "scheduled_id": 0,
                        "sub_type": "",
                        "type": "",
                        "updated": ""
                    },
                    "PaymentBatch": {}
                },
                "recurrence_size": 0,
                "recurrence_unit": "",
                "status": "",
                "time_end": "",
                "time_start": ""
            },
            "status": ""
        },
        "MasterCardAction": {
            "alias": {},
            "all_mastercard_action_refund": [
                {
                    "additional_information": {
                        "attachment": [{ "id": 0 }],
                        "category": "",
                        "comment": "",
                        "reason": "",
                        "terms_and_conditions": ""
                    },
                    "alias": {},
                    "amount": {},
                    "attachment": [{}],
                    "category": "",
                    "comment": "",
                    "counterparty_alias": {},
                    "created": "",
                    "description": "",
                    "id": 0,
                    "label_card": {
                        "expiry_date": "",
                        "label_user": {},
                        "second_line": "",
                        "status": "",
                        "type": "",
                        "uuid": ""
                    },
                    "label_user_creator": {},
                    "mastercard_action_id": 0,
                    "reason": "",
                    "reference_mastercard_action_event": [{ "event_id": 0 }],
                    "status": "",
                    "status_description": "",
                    "status_description_translated": "",
                    "status_together_url": "",
                    "sub_type": "",
                    "terms_and_conditions": "",
                    "time_refund": "",
                    "type": "",
                    "updated": ""
                }
            ],
            "amount_billing": {},
            "amount_converted": {},
            "amount_fee": {},
            "amount_local": {},
            "amount_original_billing": {},
            "amount_original_local": {},
            "applied_limit": "",
            "authorisation_status": "",
            "authorisation_type": "",
            "card_authorisation_id_response": "",
            "card_id": 0,
            "city": "",
            "clearing_expiry_time": "",
            "clearing_status": "",
            "counterparty_alias": {},
            "decision": "",
            "decision_description": "",
            "decision_description_translated": "",
            "decision_together_url": "",
            "description": "",
            "eligible_whitelist_id": 0,
            "id": 0,
            "label_card": {},
            "maturity_date": "",
            "monetary_account_id": 0,
            "pan_entry_mode_user": "",
            "payment_status": "",
            "pos_card_holder_presence": "",
            "pos_card_presence": "",
            "request_reference_split_the_bill": [{}],
            "reservation_expiry_time": "",
            "secure_code_id": 0,
            "settlement_status": "",
            "token_status": "",
            "wallet_provider_id": ""
        },
        "Payment": {},
        "PaymentBatch": {},
        "RequestResponse": {
            "address_billing": {},
            "address_shipping": {},
            "alias": {},
            "amount_inquired": {},
            "amount_responded": {},
            "attachment": [
                {
                    "content_type": "",
                    "description": "",
                    "urls": [
                        {
                            "type": "",
                            "url": ""
                        }
                    ]
                }
            ],
            "counterparty_alias": {},
            "created": "",
            "credit_scheme_identifier": "",
            "description": "",
            "eligible_whitelist_id": 0,
            "event_id": 0,
            "geolocation": {},
            "id": 0,
            "mandate_identifier": "",
            "minimum_age": 0,
            "monetary_account_id": 0,
            "redirect_url": "",
            "request_reference_split_the_bill": [{}],
            "require_address": "",
            "status": "",
            "sub_type": "",
            "time_expiry": "",
            "time_refund_requested": "",
            "time_refunded": "",
            "time_responded": "",
            "type": "",
            "updated": "",
            "user_refund_requested": {}
        },
        "ScheduleInstance": {
            "error_message": [],
            "request_reference_split_the_bill": [{}],
            "result_object": {
                "Payment": {},
                "PaymentBatch": {}
            },
            "scheduled_object": {},
            "state": "",
            "time_end": "",
            "time_start": ""
        },
        "TransferwisePayment": {
            "alias": {},
            "amount_source": {},
            "amount_target": {},
            "counterparty_alias": {},
            "monetary_account_id": "",
            "pay_in_reference": "",
            "quote": {
                "amount_fee": {},
                "amount_source": {},
                "amount_target": {},
                "created": "",
                "currency_source": "",
                "currency_target": "",
                "id": 0,
                "quote_id": "",
                "rate": "",
                "time_delivery_estimate": "",
                "time_expiry": "",
                "updated": ""
            },
            "rate": "",
            "recipient_id": "",
            "reference": "",
            "status": "",
            "status_transferwise": "",
            "status_transferwise_issue": "",
            "sub_status": "",
            "time_delivery_estimate": ""
        },
        "WhitelistResult": {
            "error_message": [],
            "id": 0,
            "monetary_account_paying_id": 0,
            "object": {
                "draftPayment": {},
                "id": 0,
                "requestResponse": {}
            },
            "request_reference_split_the_bill": [{}],
            "status": "",
            "sub_status": "",
            "whitelist": {}
        }
    },
    "request_inquiries": [
        {
            "address_billing": {},
            "address_shipping": {},
            "allow_amount_higher": False,
            "allow_amount_lower": False,
            "allow_bunqme": False,
            "amount_inquired": {},
            "amount_responded": {},
            "attachment": [{ "id": 0 }],
            "batch_id": 0,
            "bunqme_share_url": "",
            "counterparty_alias": {},
            "created": "",
            "description": "",
            "event_id": 0,
            "geolocation": {},
            "id": 0,
            "merchant_reference": "",
            "minimum_age": 0,
            "monetary_account_id": 0,
            "redirect_url": "",
            "reference_split_the_bill": {},
            "require_address": "",
            "scheduled_id": 0,
            "status": "",
            "time_expiry": "",
            "time_responded": "",
            "updated": "",
            "user_alias_created": {},
            "user_alias_revoked": {},
            "want_tip": False
        }
    ],
    "status": "",
    "total_amount_inquired": {}
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId"

payload <- "{\n  \"event_id\": 0,\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {\n                \"currency\": \"\",\n                \"value\": \"\"\n              },\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {\n              \"altitude\": 0,\n              \"latitude\": 0,\n              \"longitude\": 0,\n              \"radius\": 0\n            },\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"request_inquiries\": [\n    {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"allow_amount_higher\": false,\n      \"allow_amount_lower\": false,\n      \"allow_bunqme\": false,\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"id\": 0\n        }\n      ],\n      \"batch_id\": 0,\n      \"bunqme_share_url\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"reference_split_the_bill\": {},\n      \"require_address\": \"\",\n      \"scheduled_id\": 0,\n      \"status\": \"\",\n      \"time_expiry\": \"\",\n      \"time_responded\": \"\",\n      \"updated\": \"\",\n      \"user_alias_created\": {},\n      \"user_alias_revoked\": {},\n      \"want_tip\": false\n    }\n  ],\n  \"status\": \"\",\n  \"total_amount_inquired\": {}\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"event_id\": 0,\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {\n                \"currency\": \"\",\n                \"value\": \"\"\n              },\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {\n              \"altitude\": 0,\n              \"latitude\": 0,\n              \"longitude\": 0,\n              \"radius\": 0\n            },\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"request_inquiries\": [\n    {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"allow_amount_higher\": false,\n      \"allow_amount_lower\": false,\n      \"allow_bunqme\": false,\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"id\": 0\n        }\n      ],\n      \"batch_id\": 0,\n      \"bunqme_share_url\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"reference_split_the_bill\": {},\n      \"require_address\": \"\",\n      \"scheduled_id\": 0,\n      \"status\": \"\",\n      \"time_expiry\": \"\",\n      \"time_responded\": \"\",\n      \"updated\": \"\",\n      \"user_alias_created\": {},\n      \"user_alias_revoked\": {},\n      \"want_tip\": false\n    }\n  ],\n  \"status\": \"\",\n  \"total_amount_inquired\": {}\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"event_id\": 0,\n  \"reference_split_the_bill\": {\n    \"BillingInvoice\": {\n      \"address\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"category\": \"\",\n      \"chamber_of_commerce_number\": \"\",\n      \"counterparty_address\": {},\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"external_url\": \"\",\n      \"group\": [\n        {\n          \"instance_description\": \"\",\n          \"item\": [\n            {\n              \"billing_date\": \"\",\n              \"id\": 0,\n              \"quantity\": 0,\n              \"total_vat_exclusive\": {\n                \"currency\": \"\",\n                \"value\": \"\"\n              },\n              \"total_vat_inclusive\": {},\n              \"type_description\": \"\",\n              \"type_description_translated\": \"\",\n              \"unit_vat_exclusive\": {},\n              \"unit_vat_inclusive\": {},\n              \"vat\": 0\n            }\n          ],\n          \"product_vat_exclusive\": {},\n          \"product_vat_inclusive\": {},\n          \"type\": \"\",\n          \"type_description\": \"\",\n          \"type_description_translated\": \"\"\n        }\n      ],\n      \"id\": 0,\n      \"invoice_date\": \"\",\n      \"invoice_number\": \"\",\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"status\": \"\",\n      \"total_vat\": {},\n      \"total_vat_exclusive\": {},\n      \"total_vat_inclusive\": {},\n      \"updated\": \"\",\n      \"vat_number\": \"\"\n    },\n    \"DraftPayment\": {\n      \"entries\": [\n        {\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {\n              \"id\": 0,\n              \"monetary_account_id\": 0\n            }\n          ],\n          \"counterparty_alias\": {},\n          \"description\": \"\",\n          \"id\": 0,\n          \"merchant_reference\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"number_of_required_accepts\": 0,\n      \"previous_updated_timestamp\": \"\",\n      \"schedule\": {\n        \"object\": {\n          \"Payment\": {\n            \"address_billing\": {},\n            \"address_shipping\": {},\n            \"alias\": {},\n            \"allow_bunqto\": false,\n            \"amount\": {},\n            \"attachment\": [\n              {}\n            ],\n            \"balance_after_mutation\": {},\n            \"batch_id\": 0,\n            \"bunqto_expiry\": \"\",\n            \"bunqto_share_url\": \"\",\n            \"bunqto_status\": \"\",\n            \"bunqto_sub_status\": \"\",\n            \"bunqto_time_responded\": \"\",\n            \"counterparty_alias\": {},\n            \"created\": \"\",\n            \"description\": \"\",\n            \"geolocation\": {\n              \"altitude\": 0,\n              \"latitude\": 0,\n              \"longitude\": 0,\n              \"radius\": 0\n            },\n            \"id\": 0,\n            \"merchant_reference\": \"\",\n            \"monetary_account_id\": 0,\n            \"payment_auto_allocate_instance\": {\n              \"created\": \"\",\n              \"error_message\": [],\n              \"id\": 0,\n              \"payment_auto_allocate_id\": 0,\n              \"payment_batch\": {\n                \"payments\": {\n                  \"Payment\": []\n                }\n              },\n              \"payment_id\": 0,\n              \"status\": \"\",\n              \"updated\": \"\"\n            },\n            \"request_reference_split_the_bill\": [\n              {}\n            ],\n            \"scheduled_id\": 0,\n            \"sub_type\": \"\",\n            \"type\": \"\",\n            \"updated\": \"\"\n          },\n          \"PaymentBatch\": {}\n        },\n        \"recurrence_size\": 0,\n        \"recurrence_unit\": \"\",\n        \"status\": \"\",\n        \"time_end\": \"\",\n        \"time_start\": \"\"\n      },\n      \"status\": \"\"\n    },\n    \"MasterCardAction\": {\n      \"alias\": {},\n      \"all_mastercard_action_refund\": [\n        {\n          \"additional_information\": {\n            \"attachment\": [\n              {\n                \"id\": 0\n              }\n            ],\n            \"category\": \"\",\n            \"comment\": \"\",\n            \"reason\": \"\",\n            \"terms_and_conditions\": \"\"\n          },\n          \"alias\": {},\n          \"amount\": {},\n          \"attachment\": [\n            {}\n          ],\n          \"category\": \"\",\n          \"comment\": \"\",\n          \"counterparty_alias\": {},\n          \"created\": \"\",\n          \"description\": \"\",\n          \"id\": 0,\n          \"label_card\": {\n            \"expiry_date\": \"\",\n            \"label_user\": {},\n            \"second_line\": \"\",\n            \"status\": \"\",\n            \"type\": \"\",\n            \"uuid\": \"\"\n          },\n          \"label_user_creator\": {},\n          \"mastercard_action_id\": 0,\n          \"reason\": \"\",\n          \"reference_mastercard_action_event\": [\n            {\n              \"event_id\": 0\n            }\n          ],\n          \"status\": \"\",\n          \"status_description\": \"\",\n          \"status_description_translated\": \"\",\n          \"status_together_url\": \"\",\n          \"sub_type\": \"\",\n          \"terms_and_conditions\": \"\",\n          \"time_refund\": \"\",\n          \"type\": \"\",\n          \"updated\": \"\"\n        }\n      ],\n      \"amount_billing\": {},\n      \"amount_converted\": {},\n      \"amount_fee\": {},\n      \"amount_local\": {},\n      \"amount_original_billing\": {},\n      \"amount_original_local\": {},\n      \"applied_limit\": \"\",\n      \"authorisation_status\": \"\",\n      \"authorisation_type\": \"\",\n      \"card_authorisation_id_response\": \"\",\n      \"card_id\": 0,\n      \"city\": \"\",\n      \"clearing_expiry_time\": \"\",\n      \"clearing_status\": \"\",\n      \"counterparty_alias\": {},\n      \"decision\": \"\",\n      \"decision_description\": \"\",\n      \"decision_description_translated\": \"\",\n      \"decision_together_url\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"id\": 0,\n      \"label_card\": {},\n      \"maturity_date\": \"\",\n      \"monetary_account_id\": 0,\n      \"pan_entry_mode_user\": \"\",\n      \"payment_status\": \"\",\n      \"pos_card_holder_presence\": \"\",\n      \"pos_card_presence\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"reservation_expiry_time\": \"\",\n      \"secure_code_id\": 0,\n      \"settlement_status\": \"\",\n      \"token_status\": \"\",\n      \"wallet_provider_id\": \"\"\n    },\n    \"Payment\": {},\n    \"PaymentBatch\": {},\n    \"RequestResponse\": {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"alias\": {},\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"content_type\": \"\",\n          \"description\": \"\",\n          \"urls\": [\n            {\n              \"type\": \"\",\n              \"url\": \"\"\n            }\n          ]\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"credit_scheme_identifier\": \"\",\n      \"description\": \"\",\n      \"eligible_whitelist_id\": 0,\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"mandate_identifier\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"require_address\": \"\",\n      \"status\": \"\",\n      \"sub_type\": \"\",\n      \"time_expiry\": \"\",\n      \"time_refund_requested\": \"\",\n      \"time_refunded\": \"\",\n      \"time_responded\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\",\n      \"user_refund_requested\": {}\n    },\n    \"ScheduleInstance\": {\n      \"error_message\": [],\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"result_object\": {\n        \"Payment\": {},\n        \"PaymentBatch\": {}\n      },\n      \"scheduled_object\": {},\n      \"state\": \"\",\n      \"time_end\": \"\",\n      \"time_start\": \"\"\n    },\n    \"TransferwisePayment\": {\n      \"alias\": {},\n      \"amount_source\": {},\n      \"amount_target\": {},\n      \"counterparty_alias\": {},\n      \"monetary_account_id\": \"\",\n      \"pay_in_reference\": \"\",\n      \"quote\": {\n        \"amount_fee\": {},\n        \"amount_source\": {},\n        \"amount_target\": {},\n        \"created\": \"\",\n        \"currency_source\": \"\",\n        \"currency_target\": \"\",\n        \"id\": 0,\n        \"quote_id\": \"\",\n        \"rate\": \"\",\n        \"time_delivery_estimate\": \"\",\n        \"time_expiry\": \"\",\n        \"updated\": \"\"\n      },\n      \"rate\": \"\",\n      \"recipient_id\": \"\",\n      \"reference\": \"\",\n      \"status\": \"\",\n      \"status_transferwise\": \"\",\n      \"status_transferwise_issue\": \"\",\n      \"sub_status\": \"\",\n      \"time_delivery_estimate\": \"\"\n    },\n    \"WhitelistResult\": {\n      \"error_message\": [],\n      \"id\": 0,\n      \"monetary_account_paying_id\": 0,\n      \"object\": {\n        \"draftPayment\": {},\n        \"id\": 0,\n        \"requestResponse\": {}\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"whitelist\": {}\n    }\n  },\n  \"request_inquiries\": [\n    {\n      \"address_billing\": {},\n      \"address_shipping\": {},\n      \"allow_amount_higher\": false,\n      \"allow_amount_lower\": false,\n      \"allow_bunqme\": false,\n      \"amount_inquired\": {},\n      \"amount_responded\": {},\n      \"attachment\": [\n        {\n          \"id\": 0\n        }\n      ],\n      \"batch_id\": 0,\n      \"bunqme_share_url\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"event_id\": 0,\n      \"geolocation\": {},\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"minimum_age\": 0,\n      \"monetary_account_id\": 0,\n      \"redirect_url\": \"\",\n      \"reference_split_the_bill\": {},\n      \"require_address\": \"\",\n      \"scheduled_id\": 0,\n      \"status\": \"\",\n      \"time_expiry\": \"\",\n      \"time_responded\": \"\",\n      \"updated\": \"\",\n      \"user_alias_created\": {},\n      \"user_alias_revoked\": {},\n      \"want_tip\": false\n    }\n  ],\n  \"status\": \"\",\n  \"total_amount_inquired\": {}\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId";

    let payload = json!({
        "event_id": 0,
        "reference_split_the_bill": json!({
            "BillingInvoice": json!({
                "address": json!({
                    "city": "",
                    "country": "",
                    "extra": "",
                    "house_number": "",
                    "is_user_address_updated": false,
                    "mailbox_name": "",
                    "po_box": "",
                    "postal_code": "",
                    "province": "",
                    "street": ""
                }),
                "alias": json!({
                    "avatar": json!({
                        "anchor_uuid": "",
                        "image": (
                            json!({
                                "attachment_public_uuid": "",
                                "content_type": "",
                                "height": 0,
                                "width": 0
                            })
                        ),
                        "style": "",
                        "uuid": ""
                    }),
                    "bunq_me": json!({
                        "name": "",
                        "service": "",
                        "type": "",
                        "value": ""
                    }),
                    "country": "",
                    "display_name": "",
                    "iban": "",
                    "is_light": false,
                    "label_user": json!({
                        "avatar": json!({}),
                        "country": "",
                        "display_name": "",
                        "public_nick_name": "",
                        "uuid": ""
                    }),
                    "merchant_category_code": "",
                    "swift_account_number": "",
                    "swift_bic": "",
                    "transferwise_account_number": "",
                    "transferwise_bank_code": ""
                }),
                "category": "",
                "chamber_of_commerce_number": "",
                "counterparty_address": json!({}),
                "counterparty_alias": json!({}),
                "created": "",
                "description": "",
                "external_url": "",
                "group": (
                    json!({
                        "instance_description": "",
                        "item": (
                            json!({
                                "billing_date": "",
                                "id": 0,
                                "quantity": 0,
                                "total_vat_exclusive": json!({
                                    "currency": "",
                                    "value": ""
                                }),
                                "total_vat_inclusive": json!({}),
                                "type_description": "",
                                "type_description_translated": "",
                                "unit_vat_exclusive": json!({}),
                                "unit_vat_inclusive": json!({}),
                                "vat": 0
                            })
                        ),
                        "product_vat_exclusive": json!({}),
                        "product_vat_inclusive": json!({}),
                        "type": "",
                        "type_description": "",
                        "type_description_translated": ""
                    })
                ),
                "id": 0,
                "invoice_date": "",
                "invoice_number": "",
                "request_reference_split_the_bill": (
                    json!({
                        "id": 0,
                        "type": ""
                    })
                ),
                "status": "",
                "total_vat": json!({}),
                "total_vat_exclusive": json!({}),
                "total_vat_inclusive": json!({}),
                "updated": "",
                "vat_number": ""
            }),
            "DraftPayment": json!({
                "entries": (
                    json!({
                        "alias": json!({}),
                        "amount": json!({}),
                        "attachment": (
                            json!({
                                "id": 0,
                                "monetary_account_id": 0
                            })
                        ),
                        "counterparty_alias": json!({}),
                        "description": "",
                        "id": 0,
                        "merchant_reference": "",
                        "type": ""
                    })
                ),
                "number_of_required_accepts": 0,
                "previous_updated_timestamp": "",
                "schedule": json!({
                    "object": json!({
                        "Payment": json!({
                            "address_billing": json!({}),
                            "address_shipping": json!({}),
                            "alias": json!({}),
                            "allow_bunqto": false,
                            "amount": json!({}),
                            "attachment": (json!({})),
                            "balance_after_mutation": json!({}),
                            "batch_id": 0,
                            "bunqto_expiry": "",
                            "bunqto_share_url": "",
                            "bunqto_status": "",
                            "bunqto_sub_status": "",
                            "bunqto_time_responded": "",
                            "counterparty_alias": json!({}),
                            "created": "",
                            "description": "",
                            "geolocation": json!({
                                "altitude": 0,
                                "latitude": 0,
                                "longitude": 0,
                                "radius": 0
                            }),
                            "id": 0,
                            "merchant_reference": "",
                            "monetary_account_id": 0,
                            "payment_auto_allocate_instance": json!({
                                "created": "",
                                "error_message": (),
                                "id": 0,
                                "payment_auto_allocate_id": 0,
                                "payment_batch": json!({"payments": json!({"Payment": ()})}),
                                "payment_id": 0,
                                "status": "",
                                "updated": ""
                            }),
                            "request_reference_split_the_bill": (json!({})),
                            "scheduled_id": 0,
                            "sub_type": "",
                            "type": "",
                            "updated": ""
                        }),
                        "PaymentBatch": json!({})
                    }),
                    "recurrence_size": 0,
                    "recurrence_unit": "",
                    "status": "",
                    "time_end": "",
                    "time_start": ""
                }),
                "status": ""
            }),
            "MasterCardAction": json!({
                "alias": json!({}),
                "all_mastercard_action_refund": (
                    json!({
                        "additional_information": json!({
                            "attachment": (json!({"id": 0})),
                            "category": "",
                            "comment": "",
                            "reason": "",
                            "terms_and_conditions": ""
                        }),
                        "alias": json!({}),
                        "amount": json!({}),
                        "attachment": (json!({})),
                        "category": "",
                        "comment": "",
                        "counterparty_alias": json!({}),
                        "created": "",
                        "description": "",
                        "id": 0,
                        "label_card": json!({
                            "expiry_date": "",
                            "label_user": json!({}),
                            "second_line": "",
                            "status": "",
                            "type": "",
                            "uuid": ""
                        }),
                        "label_user_creator": json!({}),
                        "mastercard_action_id": 0,
                        "reason": "",
                        "reference_mastercard_action_event": (json!({"event_id": 0})),
                        "status": "",
                        "status_description": "",
                        "status_description_translated": "",
                        "status_together_url": "",
                        "sub_type": "",
                        "terms_and_conditions": "",
                        "time_refund": "",
                        "type": "",
                        "updated": ""
                    })
                ),
                "amount_billing": json!({}),
                "amount_converted": json!({}),
                "amount_fee": json!({}),
                "amount_local": json!({}),
                "amount_original_billing": json!({}),
                "amount_original_local": json!({}),
                "applied_limit": "",
                "authorisation_status": "",
                "authorisation_type": "",
                "card_authorisation_id_response": "",
                "card_id": 0,
                "city": "",
                "clearing_expiry_time": "",
                "clearing_status": "",
                "counterparty_alias": json!({}),
                "decision": "",
                "decision_description": "",
                "decision_description_translated": "",
                "decision_together_url": "",
                "description": "",
                "eligible_whitelist_id": 0,
                "id": 0,
                "label_card": json!({}),
                "maturity_date": "",
                "monetary_account_id": 0,
                "pan_entry_mode_user": "",
                "payment_status": "",
                "pos_card_holder_presence": "",
                "pos_card_presence": "",
                "request_reference_split_the_bill": (json!({})),
                "reservation_expiry_time": "",
                "secure_code_id": 0,
                "settlement_status": "",
                "token_status": "",
                "wallet_provider_id": ""
            }),
            "Payment": json!({}),
            "PaymentBatch": json!({}),
            "RequestResponse": json!({
                "address_billing": json!({}),
                "address_shipping": json!({}),
                "alias": json!({}),
                "amount_inquired": json!({}),
                "amount_responded": json!({}),
                "attachment": (
                    json!({
                        "content_type": "",
                        "description": "",
                        "urls": (
                            json!({
                                "type": "",
                                "url": ""
                            })
                        )
                    })
                ),
                "counterparty_alias": json!({}),
                "created": "",
                "credit_scheme_identifier": "",
                "description": "",
                "eligible_whitelist_id": 0,
                "event_id": 0,
                "geolocation": json!({}),
                "id": 0,
                "mandate_identifier": "",
                "minimum_age": 0,
                "monetary_account_id": 0,
                "redirect_url": "",
                "request_reference_split_the_bill": (json!({})),
                "require_address": "",
                "status": "",
                "sub_type": "",
                "time_expiry": "",
                "time_refund_requested": "",
                "time_refunded": "",
                "time_responded": "",
                "type": "",
                "updated": "",
                "user_refund_requested": json!({})
            }),
            "ScheduleInstance": json!({
                "error_message": (),
                "request_reference_split_the_bill": (json!({})),
                "result_object": json!({
                    "Payment": json!({}),
                    "PaymentBatch": json!({})
                }),
                "scheduled_object": json!({}),
                "state": "",
                "time_end": "",
                "time_start": ""
            }),
            "TransferwisePayment": json!({
                "alias": json!({}),
                "amount_source": json!({}),
                "amount_target": json!({}),
                "counterparty_alias": json!({}),
                "monetary_account_id": "",
                "pay_in_reference": "",
                "quote": json!({
                    "amount_fee": json!({}),
                    "amount_source": json!({}),
                    "amount_target": json!({}),
                    "created": "",
                    "currency_source": "",
                    "currency_target": "",
                    "id": 0,
                    "quote_id": "",
                    "rate": "",
                    "time_delivery_estimate": "",
                    "time_expiry": "",
                    "updated": ""
                }),
                "rate": "",
                "recipient_id": "",
                "reference": "",
                "status": "",
                "status_transferwise": "",
                "status_transferwise_issue": "",
                "sub_status": "",
                "time_delivery_estimate": ""
            }),
            "WhitelistResult": json!({
                "error_message": (),
                "id": 0,
                "monetary_account_paying_id": 0,
                "object": json!({
                    "draftPayment": json!({}),
                    "id": 0,
                    "requestResponse": json!({})
                }),
                "request_reference_split_the_bill": (json!({})),
                "status": "",
                "sub_status": "",
                "whitelist": json!({})
            })
        }),
        "request_inquiries": (
            json!({
                "address_billing": json!({}),
                "address_shipping": json!({}),
                "allow_amount_higher": false,
                "allow_amount_lower": false,
                "allow_bunqme": false,
                "amount_inquired": json!({}),
                "amount_responded": json!({}),
                "attachment": (json!({"id": 0})),
                "batch_id": 0,
                "bunqme_share_url": "",
                "counterparty_alias": json!({}),
                "created": "",
                "description": "",
                "event_id": 0,
                "geolocation": json!({}),
                "id": 0,
                "merchant_reference": "",
                "minimum_age": 0,
                "monetary_account_id": 0,
                "redirect_url": "",
                "reference_split_the_bill": json!({}),
                "require_address": "",
                "scheduled_id": 0,
                "status": "",
                "time_expiry": "",
                "time_responded": "",
                "updated": "",
                "user_alias_created": json!({}),
                "user_alias_revoked": json!({}),
                "want_tip": false
            })
        ),
        "status": "",
        "total_amount_inquired": json!({})
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "event_id": 0,
  "reference_split_the_bill": {
    "BillingInvoice": {
      "address": {
        "city": "",
        "country": "",
        "extra": "",
        "house_number": "",
        "is_user_address_updated": false,
        "mailbox_name": "",
        "po_box": "",
        "postal_code": "",
        "province": "",
        "street": ""
      },
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "category": "",
      "chamber_of_commerce_number": "",
      "counterparty_address": {},
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "external_url": "",
      "group": [
        {
          "instance_description": "",
          "item": [
            {
              "billing_date": "",
              "id": 0,
              "quantity": 0,
              "total_vat_exclusive": {
                "currency": "",
                "value": ""
              },
              "total_vat_inclusive": {},
              "type_description": "",
              "type_description_translated": "",
              "unit_vat_exclusive": {},
              "unit_vat_inclusive": {},
              "vat": 0
            }
          ],
          "product_vat_exclusive": {},
          "product_vat_inclusive": {},
          "type": "",
          "type_description": "",
          "type_description_translated": ""
        }
      ],
      "id": 0,
      "invoice_date": "",
      "invoice_number": "",
      "request_reference_split_the_bill": [
        {
          "id": 0,
          "type": ""
        }
      ],
      "status": "",
      "total_vat": {},
      "total_vat_exclusive": {},
      "total_vat_inclusive": {},
      "updated": "",
      "vat_number": ""
    },
    "DraftPayment": {
      "entries": [
        {
          "alias": {},
          "amount": {},
          "attachment": [
            {
              "id": 0,
              "monetary_account_id": 0
            }
          ],
          "counterparty_alias": {},
          "description": "",
          "id": 0,
          "merchant_reference": "",
          "type": ""
        }
      ],
      "number_of_required_accepts": 0,
      "previous_updated_timestamp": "",
      "schedule": {
        "object": {
          "Payment": {
            "address_billing": {},
            "address_shipping": {},
            "alias": {},
            "allow_bunqto": false,
            "amount": {},
            "attachment": [
              {}
            ],
            "balance_after_mutation": {},
            "batch_id": 0,
            "bunqto_expiry": "",
            "bunqto_share_url": "",
            "bunqto_status": "",
            "bunqto_sub_status": "",
            "bunqto_time_responded": "",
            "counterparty_alias": {},
            "created": "",
            "description": "",
            "geolocation": {
              "altitude": 0,
              "latitude": 0,
              "longitude": 0,
              "radius": 0
            },
            "id": 0,
            "merchant_reference": "",
            "monetary_account_id": 0,
            "payment_auto_allocate_instance": {
              "created": "",
              "error_message": [],
              "id": 0,
              "payment_auto_allocate_id": 0,
              "payment_batch": {
                "payments": {
                  "Payment": []
                }
              },
              "payment_id": 0,
              "status": "",
              "updated": ""
            },
            "request_reference_split_the_bill": [
              {}
            ],
            "scheduled_id": 0,
            "sub_type": "",
            "type": "",
            "updated": ""
          },
          "PaymentBatch": {}
        },
        "recurrence_size": 0,
        "recurrence_unit": "",
        "status": "",
        "time_end": "",
        "time_start": ""
      },
      "status": ""
    },
    "MasterCardAction": {
      "alias": {},
      "all_mastercard_action_refund": [
        {
          "additional_information": {
            "attachment": [
              {
                "id": 0
              }
            ],
            "category": "",
            "comment": "",
            "reason": "",
            "terms_and_conditions": ""
          },
          "alias": {},
          "amount": {},
          "attachment": [
            {}
          ],
          "category": "",
          "comment": "",
          "counterparty_alias": {},
          "created": "",
          "description": "",
          "id": 0,
          "label_card": {
            "expiry_date": "",
            "label_user": {},
            "second_line": "",
            "status": "",
            "type": "",
            "uuid": ""
          },
          "label_user_creator": {},
          "mastercard_action_id": 0,
          "reason": "",
          "reference_mastercard_action_event": [
            {
              "event_id": 0
            }
          ],
          "status": "",
          "status_description": "",
          "status_description_translated": "",
          "status_together_url": "",
          "sub_type": "",
          "terms_and_conditions": "",
          "time_refund": "",
          "type": "",
          "updated": ""
        }
      ],
      "amount_billing": {},
      "amount_converted": {},
      "amount_fee": {},
      "amount_local": {},
      "amount_original_billing": {},
      "amount_original_local": {},
      "applied_limit": "",
      "authorisation_status": "",
      "authorisation_type": "",
      "card_authorisation_id_response": "",
      "card_id": 0,
      "city": "",
      "clearing_expiry_time": "",
      "clearing_status": "",
      "counterparty_alias": {},
      "decision": "",
      "decision_description": "",
      "decision_description_translated": "",
      "decision_together_url": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "id": 0,
      "label_card": {},
      "maturity_date": "",
      "monetary_account_id": 0,
      "pan_entry_mode_user": "",
      "payment_status": "",
      "pos_card_holder_presence": "",
      "pos_card_presence": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "reservation_expiry_time": "",
      "secure_code_id": 0,
      "settlement_status": "",
      "token_status": "",
      "wallet_provider_id": ""
    },
    "Payment": {},
    "PaymentBatch": {},
    "RequestResponse": {
      "address_billing": {},
      "address_shipping": {},
      "alias": {},
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "content_type": "",
          "description": "",
          "urls": [
            {
              "type": "",
              "url": ""
            }
          ]
        }
      ],
      "counterparty_alias": {},
      "created": "",
      "credit_scheme_identifier": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "mandate_identifier": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "require_address": "",
      "status": "",
      "sub_type": "",
      "time_expiry": "",
      "time_refund_requested": "",
      "time_refunded": "",
      "time_responded": "",
      "type": "",
      "updated": "",
      "user_refund_requested": {}
    },
    "ScheduleInstance": {
      "error_message": [],
      "request_reference_split_the_bill": [
        {}
      ],
      "result_object": {
        "Payment": {},
        "PaymentBatch": {}
      },
      "scheduled_object": {},
      "state": "",
      "time_end": "",
      "time_start": ""
    },
    "TransferwisePayment": {
      "alias": {},
      "amount_source": {},
      "amount_target": {},
      "counterparty_alias": {},
      "monetary_account_id": "",
      "pay_in_reference": "",
      "quote": {
        "amount_fee": {},
        "amount_source": {},
        "amount_target": {},
        "created": "",
        "currency_source": "",
        "currency_target": "",
        "id": 0,
        "quote_id": "",
        "rate": "",
        "time_delivery_estimate": "",
        "time_expiry": "",
        "updated": ""
      },
      "rate": "",
      "recipient_id": "",
      "reference": "",
      "status": "",
      "status_transferwise": "",
      "status_transferwise_issue": "",
      "sub_status": "",
      "time_delivery_estimate": ""
    },
    "WhitelistResult": {
      "error_message": [],
      "id": 0,
      "monetary_account_paying_id": 0,
      "object": {
        "draftPayment": {},
        "id": 0,
        "requestResponse": {}
      },
      "request_reference_split_the_bill": [
        {}
      ],
      "status": "",
      "sub_status": "",
      "whitelist": {}
    }
  },
  "request_inquiries": [
    {
      "address_billing": {},
      "address_shipping": {},
      "allow_amount_higher": false,
      "allow_amount_lower": false,
      "allow_bunqme": false,
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "id": 0
        }
      ],
      "batch_id": 0,
      "bunqme_share_url": "",
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "merchant_reference": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "reference_split_the_bill": {},
      "require_address": "",
      "scheduled_id": 0,
      "status": "",
      "time_expiry": "",
      "time_responded": "",
      "updated": "",
      "user_alias_created": {},
      "user_alias_revoked": {},
      "want_tip": false
    }
  ],
  "status": "",
  "total_amount_inquired": {}
}'
echo '{
  "event_id": 0,
  "reference_split_the_bill": {
    "BillingInvoice": {
      "address": {
        "city": "",
        "country": "",
        "extra": "",
        "house_number": "",
        "is_user_address_updated": false,
        "mailbox_name": "",
        "po_box": "",
        "postal_code": "",
        "province": "",
        "street": ""
      },
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "category": "",
      "chamber_of_commerce_number": "",
      "counterparty_address": {},
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "external_url": "",
      "group": [
        {
          "instance_description": "",
          "item": [
            {
              "billing_date": "",
              "id": 0,
              "quantity": 0,
              "total_vat_exclusive": {
                "currency": "",
                "value": ""
              },
              "total_vat_inclusive": {},
              "type_description": "",
              "type_description_translated": "",
              "unit_vat_exclusive": {},
              "unit_vat_inclusive": {},
              "vat": 0
            }
          ],
          "product_vat_exclusive": {},
          "product_vat_inclusive": {},
          "type": "",
          "type_description": "",
          "type_description_translated": ""
        }
      ],
      "id": 0,
      "invoice_date": "",
      "invoice_number": "",
      "request_reference_split_the_bill": [
        {
          "id": 0,
          "type": ""
        }
      ],
      "status": "",
      "total_vat": {},
      "total_vat_exclusive": {},
      "total_vat_inclusive": {},
      "updated": "",
      "vat_number": ""
    },
    "DraftPayment": {
      "entries": [
        {
          "alias": {},
          "amount": {},
          "attachment": [
            {
              "id": 0,
              "monetary_account_id": 0
            }
          ],
          "counterparty_alias": {},
          "description": "",
          "id": 0,
          "merchant_reference": "",
          "type": ""
        }
      ],
      "number_of_required_accepts": 0,
      "previous_updated_timestamp": "",
      "schedule": {
        "object": {
          "Payment": {
            "address_billing": {},
            "address_shipping": {},
            "alias": {},
            "allow_bunqto": false,
            "amount": {},
            "attachment": [
              {}
            ],
            "balance_after_mutation": {},
            "batch_id": 0,
            "bunqto_expiry": "",
            "bunqto_share_url": "",
            "bunqto_status": "",
            "bunqto_sub_status": "",
            "bunqto_time_responded": "",
            "counterparty_alias": {},
            "created": "",
            "description": "",
            "geolocation": {
              "altitude": 0,
              "latitude": 0,
              "longitude": 0,
              "radius": 0
            },
            "id": 0,
            "merchant_reference": "",
            "monetary_account_id": 0,
            "payment_auto_allocate_instance": {
              "created": "",
              "error_message": [],
              "id": 0,
              "payment_auto_allocate_id": 0,
              "payment_batch": {
                "payments": {
                  "Payment": []
                }
              },
              "payment_id": 0,
              "status": "",
              "updated": ""
            },
            "request_reference_split_the_bill": [
              {}
            ],
            "scheduled_id": 0,
            "sub_type": "",
            "type": "",
            "updated": ""
          },
          "PaymentBatch": {}
        },
        "recurrence_size": 0,
        "recurrence_unit": "",
        "status": "",
        "time_end": "",
        "time_start": ""
      },
      "status": ""
    },
    "MasterCardAction": {
      "alias": {},
      "all_mastercard_action_refund": [
        {
          "additional_information": {
            "attachment": [
              {
                "id": 0
              }
            ],
            "category": "",
            "comment": "",
            "reason": "",
            "terms_and_conditions": ""
          },
          "alias": {},
          "amount": {},
          "attachment": [
            {}
          ],
          "category": "",
          "comment": "",
          "counterparty_alias": {},
          "created": "",
          "description": "",
          "id": 0,
          "label_card": {
            "expiry_date": "",
            "label_user": {},
            "second_line": "",
            "status": "",
            "type": "",
            "uuid": ""
          },
          "label_user_creator": {},
          "mastercard_action_id": 0,
          "reason": "",
          "reference_mastercard_action_event": [
            {
              "event_id": 0
            }
          ],
          "status": "",
          "status_description": "",
          "status_description_translated": "",
          "status_together_url": "",
          "sub_type": "",
          "terms_and_conditions": "",
          "time_refund": "",
          "type": "",
          "updated": ""
        }
      ],
      "amount_billing": {},
      "amount_converted": {},
      "amount_fee": {},
      "amount_local": {},
      "amount_original_billing": {},
      "amount_original_local": {},
      "applied_limit": "",
      "authorisation_status": "",
      "authorisation_type": "",
      "card_authorisation_id_response": "",
      "card_id": 0,
      "city": "",
      "clearing_expiry_time": "",
      "clearing_status": "",
      "counterparty_alias": {},
      "decision": "",
      "decision_description": "",
      "decision_description_translated": "",
      "decision_together_url": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "id": 0,
      "label_card": {},
      "maturity_date": "",
      "monetary_account_id": 0,
      "pan_entry_mode_user": "",
      "payment_status": "",
      "pos_card_holder_presence": "",
      "pos_card_presence": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "reservation_expiry_time": "",
      "secure_code_id": 0,
      "settlement_status": "",
      "token_status": "",
      "wallet_provider_id": ""
    },
    "Payment": {},
    "PaymentBatch": {},
    "RequestResponse": {
      "address_billing": {},
      "address_shipping": {},
      "alias": {},
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "content_type": "",
          "description": "",
          "urls": [
            {
              "type": "",
              "url": ""
            }
          ]
        }
      ],
      "counterparty_alias": {},
      "created": "",
      "credit_scheme_identifier": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "mandate_identifier": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "request_reference_split_the_bill": [
        {}
      ],
      "require_address": "",
      "status": "",
      "sub_type": "",
      "time_expiry": "",
      "time_refund_requested": "",
      "time_refunded": "",
      "time_responded": "",
      "type": "",
      "updated": "",
      "user_refund_requested": {}
    },
    "ScheduleInstance": {
      "error_message": [],
      "request_reference_split_the_bill": [
        {}
      ],
      "result_object": {
        "Payment": {},
        "PaymentBatch": {}
      },
      "scheduled_object": {},
      "state": "",
      "time_end": "",
      "time_start": ""
    },
    "TransferwisePayment": {
      "alias": {},
      "amount_source": {},
      "amount_target": {},
      "counterparty_alias": {},
      "monetary_account_id": "",
      "pay_in_reference": "",
      "quote": {
        "amount_fee": {},
        "amount_source": {},
        "amount_target": {},
        "created": "",
        "currency_source": "",
        "currency_target": "",
        "id": 0,
        "quote_id": "",
        "rate": "",
        "time_delivery_estimate": "",
        "time_expiry": "",
        "updated": ""
      },
      "rate": "",
      "recipient_id": "",
      "reference": "",
      "status": "",
      "status_transferwise": "",
      "status_transferwise_issue": "",
      "sub_status": "",
      "time_delivery_estimate": ""
    },
    "WhitelistResult": {
      "error_message": [],
      "id": 0,
      "monetary_account_paying_id": 0,
      "object": {
        "draftPayment": {},
        "id": 0,
        "requestResponse": {}
      },
      "request_reference_split_the_bill": [
        {}
      ],
      "status": "",
      "sub_status": "",
      "whitelist": {}
    }
  },
  "request_inquiries": [
    {
      "address_billing": {},
      "address_shipping": {},
      "allow_amount_higher": false,
      "allow_amount_lower": false,
      "allow_bunqme": false,
      "amount_inquired": {},
      "amount_responded": {},
      "attachment": [
        {
          "id": 0
        }
      ],
      "batch_id": 0,
      "bunqme_share_url": "",
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "event_id": 0,
      "geolocation": {},
      "id": 0,
      "merchant_reference": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "reference_split_the_bill": {},
      "require_address": "",
      "scheduled_id": 0,
      "status": "",
      "time_expiry": "",
      "time_responded": "",
      "updated": "",
      "user_alias_created": {},
      "user_alias_revoked": {},
      "want_tip": false
    }
  ],
  "status": "",
  "total_amount_inquired": {}
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "event_id": 0,\n  "reference_split_the_bill": {\n    "BillingInvoice": {\n      "address": {\n        "city": "",\n        "country": "",\n        "extra": "",\n        "house_number": "",\n        "is_user_address_updated": false,\n        "mailbox_name": "",\n        "po_box": "",\n        "postal_code": "",\n        "province": "",\n        "street": ""\n      },\n      "alias": {\n        "avatar": {\n          "anchor_uuid": "",\n          "image": [\n            {\n              "attachment_public_uuid": "",\n              "content_type": "",\n              "height": 0,\n              "width": 0\n            }\n          ],\n          "style": "",\n          "uuid": ""\n        },\n        "bunq_me": {\n          "name": "",\n          "service": "",\n          "type": "",\n          "value": ""\n        },\n        "country": "",\n        "display_name": "",\n        "iban": "",\n        "is_light": false,\n        "label_user": {\n          "avatar": {},\n          "country": "",\n          "display_name": "",\n          "public_nick_name": "",\n          "uuid": ""\n        },\n        "merchant_category_code": "",\n        "swift_account_number": "",\n        "swift_bic": "",\n        "transferwise_account_number": "",\n        "transferwise_bank_code": ""\n      },\n      "category": "",\n      "chamber_of_commerce_number": "",\n      "counterparty_address": {},\n      "counterparty_alias": {},\n      "created": "",\n      "description": "",\n      "external_url": "",\n      "group": [\n        {\n          "instance_description": "",\n          "item": [\n            {\n              "billing_date": "",\n              "id": 0,\n              "quantity": 0,\n              "total_vat_exclusive": {\n                "currency": "",\n                "value": ""\n              },\n              "total_vat_inclusive": {},\n              "type_description": "",\n              "type_description_translated": "",\n              "unit_vat_exclusive": {},\n              "unit_vat_inclusive": {},\n              "vat": 0\n            }\n          ],\n          "product_vat_exclusive": {},\n          "product_vat_inclusive": {},\n          "type": "",\n          "type_description": "",\n          "type_description_translated": ""\n        }\n      ],\n      "id": 0,\n      "invoice_date": "",\n      "invoice_number": "",\n      "request_reference_split_the_bill": [\n        {\n          "id": 0,\n          "type": ""\n        }\n      ],\n      "status": "",\n      "total_vat": {},\n      "total_vat_exclusive": {},\n      "total_vat_inclusive": {},\n      "updated": "",\n      "vat_number": ""\n    },\n    "DraftPayment": {\n      "entries": [\n        {\n          "alias": {},\n          "amount": {},\n          "attachment": [\n            {\n              "id": 0,\n              "monetary_account_id": 0\n            }\n          ],\n          "counterparty_alias": {},\n          "description": "",\n          "id": 0,\n          "merchant_reference": "",\n          "type": ""\n        }\n      ],\n      "number_of_required_accepts": 0,\n      "previous_updated_timestamp": "",\n      "schedule": {\n        "object": {\n          "Payment": {\n            "address_billing": {},\n            "address_shipping": {},\n            "alias": {},\n            "allow_bunqto": false,\n            "amount": {},\n            "attachment": [\n              {}\n            ],\n            "balance_after_mutation": {},\n            "batch_id": 0,\n            "bunqto_expiry": "",\n            "bunqto_share_url": "",\n            "bunqto_status": "",\n            "bunqto_sub_status": "",\n            "bunqto_time_responded": "",\n            "counterparty_alias": {},\n            "created": "",\n            "description": "",\n            "geolocation": {\n              "altitude": 0,\n              "latitude": 0,\n              "longitude": 0,\n              "radius": 0\n            },\n            "id": 0,\n            "merchant_reference": "",\n            "monetary_account_id": 0,\n            "payment_auto_allocate_instance": {\n              "created": "",\n              "error_message": [],\n              "id": 0,\n              "payment_auto_allocate_id": 0,\n              "payment_batch": {\n                "payments": {\n                  "Payment": []\n                }\n              },\n              "payment_id": 0,\n              "status": "",\n              "updated": ""\n            },\n            "request_reference_split_the_bill": [\n              {}\n            ],\n            "scheduled_id": 0,\n            "sub_type": "",\n            "type": "",\n            "updated": ""\n          },\n          "PaymentBatch": {}\n        },\n        "recurrence_size": 0,\n        "recurrence_unit": "",\n        "status": "",\n        "time_end": "",\n        "time_start": ""\n      },\n      "status": ""\n    },\n    "MasterCardAction": {\n      "alias": {},\n      "all_mastercard_action_refund": [\n        {\n          "additional_information": {\n            "attachment": [\n              {\n                "id": 0\n              }\n            ],\n            "category": "",\n            "comment": "",\n            "reason": "",\n            "terms_and_conditions": ""\n          },\n          "alias": {},\n          "amount": {},\n          "attachment": [\n            {}\n          ],\n          "category": "",\n          "comment": "",\n          "counterparty_alias": {},\n          "created": "",\n          "description": "",\n          "id": 0,\n          "label_card": {\n            "expiry_date": "",\n            "label_user": {},\n            "second_line": "",\n            "status": "",\n            "type": "",\n            "uuid": ""\n          },\n          "label_user_creator": {},\n          "mastercard_action_id": 0,\n          "reason": "",\n          "reference_mastercard_action_event": [\n            {\n              "event_id": 0\n            }\n          ],\n          "status": "",\n          "status_description": "",\n          "status_description_translated": "",\n          "status_together_url": "",\n          "sub_type": "",\n          "terms_and_conditions": "",\n          "time_refund": "",\n          "type": "",\n          "updated": ""\n        }\n      ],\n      "amount_billing": {},\n      "amount_converted": {},\n      "amount_fee": {},\n      "amount_local": {},\n      "amount_original_billing": {},\n      "amount_original_local": {},\n      "applied_limit": "",\n      "authorisation_status": "",\n      "authorisation_type": "",\n      "card_authorisation_id_response": "",\n      "card_id": 0,\n      "city": "",\n      "clearing_expiry_time": "",\n      "clearing_status": "",\n      "counterparty_alias": {},\n      "decision": "",\n      "decision_description": "",\n      "decision_description_translated": "",\n      "decision_together_url": "",\n      "description": "",\n      "eligible_whitelist_id": 0,\n      "id": 0,\n      "label_card": {},\n      "maturity_date": "",\n      "monetary_account_id": 0,\n      "pan_entry_mode_user": "",\n      "payment_status": "",\n      "pos_card_holder_presence": "",\n      "pos_card_presence": "",\n      "request_reference_split_the_bill": [\n        {}\n      ],\n      "reservation_expiry_time": "",\n      "secure_code_id": 0,\n      "settlement_status": "",\n      "token_status": "",\n      "wallet_provider_id": ""\n    },\n    "Payment": {},\n    "PaymentBatch": {},\n    "RequestResponse": {\n      "address_billing": {},\n      "address_shipping": {},\n      "alias": {},\n      "amount_inquired": {},\n      "amount_responded": {},\n      "attachment": [\n        {\n          "content_type": "",\n          "description": "",\n          "urls": [\n            {\n              "type": "",\n              "url": ""\n            }\n          ]\n        }\n      ],\n      "counterparty_alias": {},\n      "created": "",\n      "credit_scheme_identifier": "",\n      "description": "",\n      "eligible_whitelist_id": 0,\n      "event_id": 0,\n      "geolocation": {},\n      "id": 0,\n      "mandate_identifier": "",\n      "minimum_age": 0,\n      "monetary_account_id": 0,\n      "redirect_url": "",\n      "request_reference_split_the_bill": [\n        {}\n      ],\n      "require_address": "",\n      "status": "",\n      "sub_type": "",\n      "time_expiry": "",\n      "time_refund_requested": "",\n      "time_refunded": "",\n      "time_responded": "",\n      "type": "",\n      "updated": "",\n      "user_refund_requested": {}\n    },\n    "ScheduleInstance": {\n      "error_message": [],\n      "request_reference_split_the_bill": [\n        {}\n      ],\n      "result_object": {\n        "Payment": {},\n        "PaymentBatch": {}\n      },\n      "scheduled_object": {},\n      "state": "",\n      "time_end": "",\n      "time_start": ""\n    },\n    "TransferwisePayment": {\n      "alias": {},\n      "amount_source": {},\n      "amount_target": {},\n      "counterparty_alias": {},\n      "monetary_account_id": "",\n      "pay_in_reference": "",\n      "quote": {\n        "amount_fee": {},\n        "amount_source": {},\n        "amount_target": {},\n        "created": "",\n        "currency_source": "",\n        "currency_target": "",\n        "id": 0,\n        "quote_id": "",\n        "rate": "",\n        "time_delivery_estimate": "",\n        "time_expiry": "",\n        "updated": ""\n      },\n      "rate": "",\n      "recipient_id": "",\n      "reference": "",\n      "status": "",\n      "status_transferwise": "",\n      "status_transferwise_issue": "",\n      "sub_status": "",\n      "time_delivery_estimate": ""\n    },\n    "WhitelistResult": {\n      "error_message": [],\n      "id": 0,\n      "monetary_account_paying_id": 0,\n      "object": {\n        "draftPayment": {},\n        "id": 0,\n        "requestResponse": {}\n      },\n      "request_reference_split_the_bill": [\n        {}\n      ],\n      "status": "",\n      "sub_status": "",\n      "whitelist": {}\n    }\n  },\n  "request_inquiries": [\n    {\n      "address_billing": {},\n      "address_shipping": {},\n      "allow_amount_higher": false,\n      "allow_amount_lower": false,\n      "allow_bunqme": false,\n      "amount_inquired": {},\n      "amount_responded": {},\n      "attachment": [\n        {\n          "id": 0\n        }\n      ],\n      "batch_id": 0,\n      "bunqme_share_url": "",\n      "counterparty_alias": {},\n      "created": "",\n      "description": "",\n      "event_id": 0,\n      "geolocation": {},\n      "id": 0,\n      "merchant_reference": "",\n      "minimum_age": 0,\n      "monetary_account_id": 0,\n      "redirect_url": "",\n      "reference_split_the_bill": {},\n      "require_address": "",\n      "scheduled_id": 0,\n      "status": "",\n      "time_expiry": "",\n      "time_responded": "",\n      "updated": "",\n      "user_alias_created": {},\n      "user_alias_revoked": {},\n      "want_tip": false\n    }\n  ],\n  "status": "",\n  "total_amount_inquired": {}\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "event_id": 0,
  "reference_split_the_bill": [
    "BillingInvoice": [
      "address": [
        "city": "",
        "country": "",
        "extra": "",
        "house_number": "",
        "is_user_address_updated": false,
        "mailbox_name": "",
        "po_box": "",
        "postal_code": "",
        "province": "",
        "street": ""
      ],
      "alias": [
        "avatar": [
          "anchor_uuid": "",
          "image": [
            [
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            ]
          ],
          "style": "",
          "uuid": ""
        ],
        "bunq_me": [
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        ],
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": [
          "avatar": [],
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        ],
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      ],
      "category": "",
      "chamber_of_commerce_number": "",
      "counterparty_address": [],
      "counterparty_alias": [],
      "created": "",
      "description": "",
      "external_url": "",
      "group": [
        [
          "instance_description": "",
          "item": [
            [
              "billing_date": "",
              "id": 0,
              "quantity": 0,
              "total_vat_exclusive": [
                "currency": "",
                "value": ""
              ],
              "total_vat_inclusive": [],
              "type_description": "",
              "type_description_translated": "",
              "unit_vat_exclusive": [],
              "unit_vat_inclusive": [],
              "vat": 0
            ]
          ],
          "product_vat_exclusive": [],
          "product_vat_inclusive": [],
          "type": "",
          "type_description": "",
          "type_description_translated": ""
        ]
      ],
      "id": 0,
      "invoice_date": "",
      "invoice_number": "",
      "request_reference_split_the_bill": [
        [
          "id": 0,
          "type": ""
        ]
      ],
      "status": "",
      "total_vat": [],
      "total_vat_exclusive": [],
      "total_vat_inclusive": [],
      "updated": "",
      "vat_number": ""
    ],
    "DraftPayment": [
      "entries": [
        [
          "alias": [],
          "amount": [],
          "attachment": [
            [
              "id": 0,
              "monetary_account_id": 0
            ]
          ],
          "counterparty_alias": [],
          "description": "",
          "id": 0,
          "merchant_reference": "",
          "type": ""
        ]
      ],
      "number_of_required_accepts": 0,
      "previous_updated_timestamp": "",
      "schedule": [
        "object": [
          "Payment": [
            "address_billing": [],
            "address_shipping": [],
            "alias": [],
            "allow_bunqto": false,
            "amount": [],
            "attachment": [[]],
            "balance_after_mutation": [],
            "batch_id": 0,
            "bunqto_expiry": "",
            "bunqto_share_url": "",
            "bunqto_status": "",
            "bunqto_sub_status": "",
            "bunqto_time_responded": "",
            "counterparty_alias": [],
            "created": "",
            "description": "",
            "geolocation": [
              "altitude": 0,
              "latitude": 0,
              "longitude": 0,
              "radius": 0
            ],
            "id": 0,
            "merchant_reference": "",
            "monetary_account_id": 0,
            "payment_auto_allocate_instance": [
              "created": "",
              "error_message": [],
              "id": 0,
              "payment_auto_allocate_id": 0,
              "payment_batch": ["payments": ["Payment": []]],
              "payment_id": 0,
              "status": "",
              "updated": ""
            ],
            "request_reference_split_the_bill": [[]],
            "scheduled_id": 0,
            "sub_type": "",
            "type": "",
            "updated": ""
          ],
          "PaymentBatch": []
        ],
        "recurrence_size": 0,
        "recurrence_unit": "",
        "status": "",
        "time_end": "",
        "time_start": ""
      ],
      "status": ""
    ],
    "MasterCardAction": [
      "alias": [],
      "all_mastercard_action_refund": [
        [
          "additional_information": [
            "attachment": [["id": 0]],
            "category": "",
            "comment": "",
            "reason": "",
            "terms_and_conditions": ""
          ],
          "alias": [],
          "amount": [],
          "attachment": [[]],
          "category": "",
          "comment": "",
          "counterparty_alias": [],
          "created": "",
          "description": "",
          "id": 0,
          "label_card": [
            "expiry_date": "",
            "label_user": [],
            "second_line": "",
            "status": "",
            "type": "",
            "uuid": ""
          ],
          "label_user_creator": [],
          "mastercard_action_id": 0,
          "reason": "",
          "reference_mastercard_action_event": [["event_id": 0]],
          "status": "",
          "status_description": "",
          "status_description_translated": "",
          "status_together_url": "",
          "sub_type": "",
          "terms_and_conditions": "",
          "time_refund": "",
          "type": "",
          "updated": ""
        ]
      ],
      "amount_billing": [],
      "amount_converted": [],
      "amount_fee": [],
      "amount_local": [],
      "amount_original_billing": [],
      "amount_original_local": [],
      "applied_limit": "",
      "authorisation_status": "",
      "authorisation_type": "",
      "card_authorisation_id_response": "",
      "card_id": 0,
      "city": "",
      "clearing_expiry_time": "",
      "clearing_status": "",
      "counterparty_alias": [],
      "decision": "",
      "decision_description": "",
      "decision_description_translated": "",
      "decision_together_url": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "id": 0,
      "label_card": [],
      "maturity_date": "",
      "monetary_account_id": 0,
      "pan_entry_mode_user": "",
      "payment_status": "",
      "pos_card_holder_presence": "",
      "pos_card_presence": "",
      "request_reference_split_the_bill": [[]],
      "reservation_expiry_time": "",
      "secure_code_id": 0,
      "settlement_status": "",
      "token_status": "",
      "wallet_provider_id": ""
    ],
    "Payment": [],
    "PaymentBatch": [],
    "RequestResponse": [
      "address_billing": [],
      "address_shipping": [],
      "alias": [],
      "amount_inquired": [],
      "amount_responded": [],
      "attachment": [
        [
          "content_type": "",
          "description": "",
          "urls": [
            [
              "type": "",
              "url": ""
            ]
          ]
        ]
      ],
      "counterparty_alias": [],
      "created": "",
      "credit_scheme_identifier": "",
      "description": "",
      "eligible_whitelist_id": 0,
      "event_id": 0,
      "geolocation": [],
      "id": 0,
      "mandate_identifier": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "request_reference_split_the_bill": [[]],
      "require_address": "",
      "status": "",
      "sub_type": "",
      "time_expiry": "",
      "time_refund_requested": "",
      "time_refunded": "",
      "time_responded": "",
      "type": "",
      "updated": "",
      "user_refund_requested": []
    ],
    "ScheduleInstance": [
      "error_message": [],
      "request_reference_split_the_bill": [[]],
      "result_object": [
        "Payment": [],
        "PaymentBatch": []
      ],
      "scheduled_object": [],
      "state": "",
      "time_end": "",
      "time_start": ""
    ],
    "TransferwisePayment": [
      "alias": [],
      "amount_source": [],
      "amount_target": [],
      "counterparty_alias": [],
      "monetary_account_id": "",
      "pay_in_reference": "",
      "quote": [
        "amount_fee": [],
        "amount_source": [],
        "amount_target": [],
        "created": "",
        "currency_source": "",
        "currency_target": "",
        "id": 0,
        "quote_id": "",
        "rate": "",
        "time_delivery_estimate": "",
        "time_expiry": "",
        "updated": ""
      ],
      "rate": "",
      "recipient_id": "",
      "reference": "",
      "status": "",
      "status_transferwise": "",
      "status_transferwise_issue": "",
      "sub_status": "",
      "time_delivery_estimate": ""
    ],
    "WhitelistResult": [
      "error_message": [],
      "id": 0,
      "monetary_account_paying_id": 0,
      "object": [
        "draftPayment": [],
        "id": 0,
        "requestResponse": []
      ],
      "request_reference_split_the_bill": [[]],
      "status": "",
      "sub_status": "",
      "whitelist": []
    ]
  ],
  "request_inquiries": [
    [
      "address_billing": [],
      "address_shipping": [],
      "allow_amount_higher": false,
      "allow_amount_lower": false,
      "allow_bunqme": false,
      "amount_inquired": [],
      "amount_responded": [],
      "attachment": [["id": 0]],
      "batch_id": 0,
      "bunqme_share_url": "",
      "counterparty_alias": [],
      "created": "",
      "description": "",
      "event_id": 0,
      "geolocation": [],
      "id": 0,
      "merchant_reference": "",
      "minimum_age": 0,
      "monetary_account_id": 0,
      "redirect_url": "",
      "reference_split_the_bill": [],
      "require_address": "",
      "scheduled_id": 0,
      "status": "",
      "time_expiry": "",
      "time_responded": "",
      "updated": "",
      "user_alias_created": [],
      "user_alias_revoked": [],
      "want_tip": false
    ]
  ],
  "status": "",
  "total_amount_inquired": []
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-inquiry-batch/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_RequestResponse_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response" {:headers {:user-agent ""
                                                                                                                        :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_RequestResponse_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId" {:headers {:user-agent ""
                                                                                                                                :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_RequestResponse_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
itemId
BODY json

{
  "address_billing": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_shipping": {},
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "amount_inquired": {
    "currency": "",
    "value": ""
  },
  "amount_responded": {},
  "attachment": [
    {
      "content_type": "",
      "description": "",
      "urls": [
        {
          "type": "",
          "url": ""
        }
      ]
    }
  ],
  "counterparty_alias": {},
  "created": "",
  "credit_scheme_identifier": "",
  "description": "",
  "eligible_whitelist_id": 0,
  "event_id": 0,
  "geolocation": {
    "altitude": 0,
    "latitude": 0,
    "longitude": 0,
    "radius": 0
  },
  "id": 0,
  "mandate_identifier": "",
  "minimum_age": 0,
  "monetary_account_id": 0,
  "redirect_url": "",
  "request_reference_split_the_bill": [
    {
      "id": 0,
      "type": ""
    }
  ],
  "require_address": "",
  "status": "",
  "sub_type": "",
  "time_expiry": "",
  "time_refund_requested": "",
  "time_refunded": "",
  "time_responded": "",
  "type": "",
  "updated": "",
  "user_refund_requested": {}
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"content_type\": \"\",\n      \"description\": \"\",\n      \"urls\": [\n        {\n          \"type\": \"\",\n          \"url\": \"\"\n        }\n      ]\n    }\n  ],\n  \"counterparty_alias\": {},\n  \"created\": \"\",\n  \"credit_scheme_identifier\": \"\",\n  \"description\": \"\",\n  \"eligible_whitelist_id\": 0,\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"mandate_identifier\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"require_address\": \"\",\n  \"status\": \"\",\n  \"sub_type\": \"\",\n  \"time_expiry\": \"\",\n  \"time_refund_requested\": \"\",\n  \"time_refunded\": \"\",\n  \"time_responded\": \"\",\n  \"type\": \"\",\n  \"updated\": \"\",\n  \"user_refund_requested\": {}\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId" {:headers {:user-agent ""
                                                                                                                                :x-bunq-client-authentication ""}
                                                                                                                      :content-type :json
                                                                                                                      :form-params {:address_billing {:city ""
                                                                                                                                                      :country ""
                                                                                                                                                      :extra ""
                                                                                                                                                      :house_number ""
                                                                                                                                                      :is_user_address_updated false
                                                                                                                                                      :mailbox_name ""
                                                                                                                                                      :po_box ""
                                                                                                                                                      :postal_code ""
                                                                                                                                                      :province ""
                                                                                                                                                      :street ""}
                                                                                                                                    :address_shipping {}
                                                                                                                                    :alias {:avatar {:anchor_uuid ""
                                                                                                                                                     :image [{:attachment_public_uuid ""
                                                                                                                                                              :content_type ""
                                                                                                                                                              :height 0
                                                                                                                                                              :width 0}]
                                                                                                                                                     :style ""
                                                                                                                                                     :uuid ""}
                                                                                                                                            :bunq_me {:name ""
                                                                                                                                                      :service ""
                                                                                                                                                      :type ""
                                                                                                                                                      :value ""}
                                                                                                                                            :country ""
                                                                                                                                            :display_name ""
                                                                                                                                            :iban ""
                                                                                                                                            :is_light false
                                                                                                                                            :label_user {:avatar {}
                                                                                                                                                         :country ""
                                                                                                                                                         :display_name ""
                                                                                                                                                         :public_nick_name ""
                                                                                                                                                         :uuid ""}
                                                                                                                                            :merchant_category_code ""
                                                                                                                                            :swift_account_number ""
                                                                                                                                            :swift_bic ""
                                                                                                                                            :transferwise_account_number ""
                                                                                                                                            :transferwise_bank_code ""}
                                                                                                                                    :amount_inquired {:currency ""
                                                                                                                                                      :value ""}
                                                                                                                                    :amount_responded {}
                                                                                                                                    :attachment [{:content_type ""
                                                                                                                                                  :description ""
                                                                                                                                                  :urls [{:type ""
                                                                                                                                                          :url ""}]}]
                                                                                                                                    :counterparty_alias {}
                                                                                                                                    :created ""
                                                                                                                                    :credit_scheme_identifier ""
                                                                                                                                    :description ""
                                                                                                                                    :eligible_whitelist_id 0
                                                                                                                                    :event_id 0
                                                                                                                                    :geolocation {:altitude 0
                                                                                                                                                  :latitude 0
                                                                                                                                                  :longitude 0
                                                                                                                                                  :radius 0}
                                                                                                                                    :id 0
                                                                                                                                    :mandate_identifier ""
                                                                                                                                    :minimum_age 0
                                                                                                                                    :monetary_account_id 0
                                                                                                                                    :redirect_url ""
                                                                                                                                    :request_reference_split_the_bill [{:id 0
                                                                                                                                                                        :type ""}]
                                                                                                                                    :require_address ""
                                                                                                                                    :status ""
                                                                                                                                    :sub_type ""
                                                                                                                                    :time_expiry ""
                                                                                                                                    :time_refund_requested ""
                                                                                                                                    :time_refunded ""
                                                                                                                                    :time_responded ""
                                                                                                                                    :type ""
                                                                                                                                    :updated ""
                                                                                                                                    :user_refund_requested {}}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"content_type\": \"\",\n      \"description\": \"\",\n      \"urls\": [\n        {\n          \"type\": \"\",\n          \"url\": \"\"\n        }\n      ]\n    }\n  ],\n  \"counterparty_alias\": {},\n  \"created\": \"\",\n  \"credit_scheme_identifier\": \"\",\n  \"description\": \"\",\n  \"eligible_whitelist_id\": 0,\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"mandate_identifier\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"require_address\": \"\",\n  \"status\": \"\",\n  \"sub_type\": \"\",\n  \"time_expiry\": \"\",\n  \"time_refund_requested\": \"\",\n  \"time_refunded\": \"\",\n  \"time_responded\": \"\",\n  \"type\": \"\",\n  \"updated\": \"\",\n  \"user_refund_requested\": {}\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"content_type\": \"\",\n      \"description\": \"\",\n      \"urls\": [\n        {\n          \"type\": \"\",\n          \"url\": \"\"\n        }\n      ]\n    }\n  ],\n  \"counterparty_alias\": {},\n  \"created\": \"\",\n  \"credit_scheme_identifier\": \"\",\n  \"description\": \"\",\n  \"eligible_whitelist_id\": 0,\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"mandate_identifier\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"require_address\": \"\",\n  \"status\": \"\",\n  \"sub_type\": \"\",\n  \"time_expiry\": \"\",\n  \"time_refund_requested\": \"\",\n  \"time_refunded\": \"\",\n  \"time_responded\": \"\",\n  \"type\": \"\",\n  \"updated\": \"\",\n  \"user_refund_requested\": {}\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"content_type\": \"\",\n      \"description\": \"\",\n      \"urls\": [\n        {\n          \"type\": \"\",\n          \"url\": \"\"\n        }\n      ]\n    }\n  ],\n  \"counterparty_alias\": {},\n  \"created\": \"\",\n  \"credit_scheme_identifier\": \"\",\n  \"description\": \"\",\n  \"eligible_whitelist_id\": 0,\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"mandate_identifier\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"require_address\": \"\",\n  \"status\": \"\",\n  \"sub_type\": \"\",\n  \"time_expiry\": \"\",\n  \"time_refund_requested\": \"\",\n  \"time_refunded\": \"\",\n  \"time_responded\": \"\",\n  \"type\": \"\",\n  \"updated\": \"\",\n  \"user_refund_requested\": {}\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId"

	payload := strings.NewReader("{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"content_type\": \"\",\n      \"description\": \"\",\n      \"urls\": [\n        {\n          \"type\": \"\",\n          \"url\": \"\"\n        }\n      ]\n    }\n  ],\n  \"counterparty_alias\": {},\n  \"created\": \"\",\n  \"credit_scheme_identifier\": \"\",\n  \"description\": \"\",\n  \"eligible_whitelist_id\": 0,\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"mandate_identifier\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"require_address\": \"\",\n  \"status\": \"\",\n  \"sub_type\": \"\",\n  \"time_expiry\": \"\",\n  \"time_refund_requested\": \"\",\n  \"time_refunded\": \"\",\n  \"time_responded\": \"\",\n  \"type\": \"\",\n  \"updated\": \"\",\n  \"user_refund_requested\": {}\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 1940

{
  "address_billing": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_shipping": {},
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "amount_inquired": {
    "currency": "",
    "value": ""
  },
  "amount_responded": {},
  "attachment": [
    {
      "content_type": "",
      "description": "",
      "urls": [
        {
          "type": "",
          "url": ""
        }
      ]
    }
  ],
  "counterparty_alias": {},
  "created": "",
  "credit_scheme_identifier": "",
  "description": "",
  "eligible_whitelist_id": 0,
  "event_id": 0,
  "geolocation": {
    "altitude": 0,
    "latitude": 0,
    "longitude": 0,
    "radius": 0
  },
  "id": 0,
  "mandate_identifier": "",
  "minimum_age": 0,
  "monetary_account_id": 0,
  "redirect_url": "",
  "request_reference_split_the_bill": [
    {
      "id": 0,
      "type": ""
    }
  ],
  "require_address": "",
  "status": "",
  "sub_type": "",
  "time_expiry": "",
  "time_refund_requested": "",
  "time_refunded": "",
  "time_responded": "",
  "type": "",
  "updated": "",
  "user_refund_requested": {}
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"content_type\": \"\",\n      \"description\": \"\",\n      \"urls\": [\n        {\n          \"type\": \"\",\n          \"url\": \"\"\n        }\n      ]\n    }\n  ],\n  \"counterparty_alias\": {},\n  \"created\": \"\",\n  \"credit_scheme_identifier\": \"\",\n  \"description\": \"\",\n  \"eligible_whitelist_id\": 0,\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"mandate_identifier\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"require_address\": \"\",\n  \"status\": \"\",\n  \"sub_type\": \"\",\n  \"time_expiry\": \"\",\n  \"time_refund_requested\": \"\",\n  \"time_refunded\": \"\",\n  \"time_responded\": \"\",\n  \"type\": \"\",\n  \"updated\": \"\",\n  \"user_refund_requested\": {}\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"content_type\": \"\",\n      \"description\": \"\",\n      \"urls\": [\n        {\n          \"type\": \"\",\n          \"url\": \"\"\n        }\n      ]\n    }\n  ],\n  \"counterparty_alias\": {},\n  \"created\": \"\",\n  \"credit_scheme_identifier\": \"\",\n  \"description\": \"\",\n  \"eligible_whitelist_id\": 0,\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"mandate_identifier\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"require_address\": \"\",\n  \"status\": \"\",\n  \"sub_type\": \"\",\n  \"time_expiry\": \"\",\n  \"time_refund_requested\": \"\",\n  \"time_refunded\": \"\",\n  \"time_responded\": \"\",\n  \"type\": \"\",\n  \"updated\": \"\",\n  \"user_refund_requested\": {}\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"content_type\": \"\",\n      \"description\": \"\",\n      \"urls\": [\n        {\n          \"type\": \"\",\n          \"url\": \"\"\n        }\n      ]\n    }\n  ],\n  \"counterparty_alias\": {},\n  \"created\": \"\",\n  \"credit_scheme_identifier\": \"\",\n  \"description\": \"\",\n  \"eligible_whitelist_id\": 0,\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"mandate_identifier\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"require_address\": \"\",\n  \"status\": \"\",\n  \"sub_type\": \"\",\n  \"time_expiry\": \"\",\n  \"time_refund_requested\": \"\",\n  \"time_refunded\": \"\",\n  \"time_responded\": \"\",\n  \"type\": \"\",\n  \"updated\": \"\",\n  \"user_refund_requested\": {}\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"content_type\": \"\",\n      \"description\": \"\",\n      \"urls\": [\n        {\n          \"type\": \"\",\n          \"url\": \"\"\n        }\n      ]\n    }\n  ],\n  \"counterparty_alias\": {},\n  \"created\": \"\",\n  \"credit_scheme_identifier\": \"\",\n  \"description\": \"\",\n  \"eligible_whitelist_id\": 0,\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"mandate_identifier\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"require_address\": \"\",\n  \"status\": \"\",\n  \"sub_type\": \"\",\n  \"time_expiry\": \"\",\n  \"time_refund_requested\": \"\",\n  \"time_refunded\": \"\",\n  \"time_responded\": \"\",\n  \"type\": \"\",\n  \"updated\": \"\",\n  \"user_refund_requested\": {}\n}")
  .asString();
const data = JSON.stringify({
  address_billing: {
    city: '',
    country: '',
    extra: '',
    house_number: '',
    is_user_address_updated: false,
    mailbox_name: '',
    po_box: '',
    postal_code: '',
    province: '',
    street: ''
  },
  address_shipping: {},
  alias: {
    avatar: {
      anchor_uuid: '',
      image: [
        {
          attachment_public_uuid: '',
          content_type: '',
          height: 0,
          width: 0
        }
      ],
      style: '',
      uuid: ''
    },
    bunq_me: {
      name: '',
      service: '',
      type: '',
      value: ''
    },
    country: '',
    display_name: '',
    iban: '',
    is_light: false,
    label_user: {
      avatar: {},
      country: '',
      display_name: '',
      public_nick_name: '',
      uuid: ''
    },
    merchant_category_code: '',
    swift_account_number: '',
    swift_bic: '',
    transferwise_account_number: '',
    transferwise_bank_code: ''
  },
  amount_inquired: {
    currency: '',
    value: ''
  },
  amount_responded: {},
  attachment: [
    {
      content_type: '',
      description: '',
      urls: [
        {
          type: '',
          url: ''
        }
      ]
    }
  ],
  counterparty_alias: {},
  created: '',
  credit_scheme_identifier: '',
  description: '',
  eligible_whitelist_id: 0,
  event_id: 0,
  geolocation: {
    altitude: 0,
    latitude: 0,
    longitude: 0,
    radius: 0
  },
  id: 0,
  mandate_identifier: '',
  minimum_age: 0,
  monetary_account_id: 0,
  redirect_url: '',
  request_reference_split_the_bill: [
    {
      id: 0,
      type: ''
    }
  ],
  require_address: '',
  status: '',
  sub_type: '',
  time_expiry: '',
  time_refund_requested: '',
  time_refunded: '',
  time_responded: '',
  type: '',
  updated: '',
  user_refund_requested: {}
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    address_billing: {
      city: '',
      country: '',
      extra: '',
      house_number: '',
      is_user_address_updated: false,
      mailbox_name: '',
      po_box: '',
      postal_code: '',
      province: '',
      street: ''
    },
    address_shipping: {},
    alias: {
      avatar: {
        anchor_uuid: '',
        image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
        style: '',
        uuid: ''
      },
      bunq_me: {name: '', service: '', type: '', value: ''},
      country: '',
      display_name: '',
      iban: '',
      is_light: false,
      label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
      merchant_category_code: '',
      swift_account_number: '',
      swift_bic: '',
      transferwise_account_number: '',
      transferwise_bank_code: ''
    },
    amount_inquired: {currency: '', value: ''},
    amount_responded: {},
    attachment: [{content_type: '', description: '', urls: [{type: '', url: ''}]}],
    counterparty_alias: {},
    created: '',
    credit_scheme_identifier: '',
    description: '',
    eligible_whitelist_id: 0,
    event_id: 0,
    geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
    id: 0,
    mandate_identifier: '',
    minimum_age: 0,
    monetary_account_id: 0,
    redirect_url: '',
    request_reference_split_the_bill: [{id: 0, type: ''}],
    require_address: '',
    status: '',
    sub_type: '',
    time_expiry: '',
    time_refund_requested: '',
    time_refunded: '',
    time_responded: '',
    type: '',
    updated: '',
    user_refund_requested: {}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"address_billing":{"city":"","country":"","extra":"","house_number":"","is_user_address_updated":false,"mailbox_name":"","po_box":"","postal_code":"","province":"","street":""},"address_shipping":{},"alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"amount_inquired":{"currency":"","value":""},"amount_responded":{},"attachment":[{"content_type":"","description":"","urls":[{"type":"","url":""}]}],"counterparty_alias":{},"created":"","credit_scheme_identifier":"","description":"","eligible_whitelist_id":0,"event_id":0,"geolocation":{"altitude":0,"latitude":0,"longitude":0,"radius":0},"id":0,"mandate_identifier":"","minimum_age":0,"monetary_account_id":0,"redirect_url":"","request_reference_split_the_bill":[{"id":0,"type":""}],"require_address":"","status":"","sub_type":"","time_expiry":"","time_refund_requested":"","time_refunded":"","time_responded":"","type":"","updated":"","user_refund_requested":{}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "address_billing": {\n    "city": "",\n    "country": "",\n    "extra": "",\n    "house_number": "",\n    "is_user_address_updated": false,\n    "mailbox_name": "",\n    "po_box": "",\n    "postal_code": "",\n    "province": "",\n    "street": ""\n  },\n  "address_shipping": {},\n  "alias": {\n    "avatar": {\n      "anchor_uuid": "",\n      "image": [\n        {\n          "attachment_public_uuid": "",\n          "content_type": "",\n          "height": 0,\n          "width": 0\n        }\n      ],\n      "style": "",\n      "uuid": ""\n    },\n    "bunq_me": {\n      "name": "",\n      "service": "",\n      "type": "",\n      "value": ""\n    },\n    "country": "",\n    "display_name": "",\n    "iban": "",\n    "is_light": false,\n    "label_user": {\n      "avatar": {},\n      "country": "",\n      "display_name": "",\n      "public_nick_name": "",\n      "uuid": ""\n    },\n    "merchant_category_code": "",\n    "swift_account_number": "",\n    "swift_bic": "",\n    "transferwise_account_number": "",\n    "transferwise_bank_code": ""\n  },\n  "amount_inquired": {\n    "currency": "",\n    "value": ""\n  },\n  "amount_responded": {},\n  "attachment": [\n    {\n      "content_type": "",\n      "description": "",\n      "urls": [\n        {\n          "type": "",\n          "url": ""\n        }\n      ]\n    }\n  ],\n  "counterparty_alias": {},\n  "created": "",\n  "credit_scheme_identifier": "",\n  "description": "",\n  "eligible_whitelist_id": 0,\n  "event_id": 0,\n  "geolocation": {\n    "altitude": 0,\n    "latitude": 0,\n    "longitude": 0,\n    "radius": 0\n  },\n  "id": 0,\n  "mandate_identifier": "",\n  "minimum_age": 0,\n  "monetary_account_id": 0,\n  "redirect_url": "",\n  "request_reference_split_the_bill": [\n    {\n      "id": 0,\n      "type": ""\n    }\n  ],\n  "require_address": "",\n  "status": "",\n  "sub_type": "",\n  "time_expiry": "",\n  "time_refund_requested": "",\n  "time_refunded": "",\n  "time_responded": "",\n  "type": "",\n  "updated": "",\n  "user_refund_requested": {}\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"content_type\": \"\",\n      \"description\": \"\",\n      \"urls\": [\n        {\n          \"type\": \"\",\n          \"url\": \"\"\n        }\n      ]\n    }\n  ],\n  \"counterparty_alias\": {},\n  \"created\": \"\",\n  \"credit_scheme_identifier\": \"\",\n  \"description\": \"\",\n  \"eligible_whitelist_id\": 0,\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"mandate_identifier\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"require_address\": \"\",\n  \"status\": \"\",\n  \"sub_type\": \"\",\n  \"time_expiry\": \"\",\n  \"time_refund_requested\": \"\",\n  \"time_refunded\": \"\",\n  \"time_responded\": \"\",\n  \"type\": \"\",\n  \"updated\": \"\",\n  \"user_refund_requested\": {}\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  address_billing: {
    city: '',
    country: '',
    extra: '',
    house_number: '',
    is_user_address_updated: false,
    mailbox_name: '',
    po_box: '',
    postal_code: '',
    province: '',
    street: ''
  },
  address_shipping: {},
  alias: {
    avatar: {
      anchor_uuid: '',
      image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
      style: '',
      uuid: ''
    },
    bunq_me: {name: '', service: '', type: '', value: ''},
    country: '',
    display_name: '',
    iban: '',
    is_light: false,
    label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
    merchant_category_code: '',
    swift_account_number: '',
    swift_bic: '',
    transferwise_account_number: '',
    transferwise_bank_code: ''
  },
  amount_inquired: {currency: '', value: ''},
  amount_responded: {},
  attachment: [{content_type: '', description: '', urls: [{type: '', url: ''}]}],
  counterparty_alias: {},
  created: '',
  credit_scheme_identifier: '',
  description: '',
  eligible_whitelist_id: 0,
  event_id: 0,
  geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
  id: 0,
  mandate_identifier: '',
  minimum_age: 0,
  monetary_account_id: 0,
  redirect_url: '',
  request_reference_split_the_bill: [{id: 0, type: ''}],
  require_address: '',
  status: '',
  sub_type: '',
  time_expiry: '',
  time_refund_requested: '',
  time_refunded: '',
  time_responded: '',
  type: '',
  updated: '',
  user_refund_requested: {}
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    address_billing: {
      city: '',
      country: '',
      extra: '',
      house_number: '',
      is_user_address_updated: false,
      mailbox_name: '',
      po_box: '',
      postal_code: '',
      province: '',
      street: ''
    },
    address_shipping: {},
    alias: {
      avatar: {
        anchor_uuid: '',
        image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
        style: '',
        uuid: ''
      },
      bunq_me: {name: '', service: '', type: '', value: ''},
      country: '',
      display_name: '',
      iban: '',
      is_light: false,
      label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
      merchant_category_code: '',
      swift_account_number: '',
      swift_bic: '',
      transferwise_account_number: '',
      transferwise_bank_code: ''
    },
    amount_inquired: {currency: '', value: ''},
    amount_responded: {},
    attachment: [{content_type: '', description: '', urls: [{type: '', url: ''}]}],
    counterparty_alias: {},
    created: '',
    credit_scheme_identifier: '',
    description: '',
    eligible_whitelist_id: 0,
    event_id: 0,
    geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
    id: 0,
    mandate_identifier: '',
    minimum_age: 0,
    monetary_account_id: 0,
    redirect_url: '',
    request_reference_split_the_bill: [{id: 0, type: ''}],
    require_address: '',
    status: '',
    sub_type: '',
    time_expiry: '',
    time_refund_requested: '',
    time_refunded: '',
    time_responded: '',
    type: '',
    updated: '',
    user_refund_requested: {}
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  address_billing: {
    city: '',
    country: '',
    extra: '',
    house_number: '',
    is_user_address_updated: false,
    mailbox_name: '',
    po_box: '',
    postal_code: '',
    province: '',
    street: ''
  },
  address_shipping: {},
  alias: {
    avatar: {
      anchor_uuid: '',
      image: [
        {
          attachment_public_uuid: '',
          content_type: '',
          height: 0,
          width: 0
        }
      ],
      style: '',
      uuid: ''
    },
    bunq_me: {
      name: '',
      service: '',
      type: '',
      value: ''
    },
    country: '',
    display_name: '',
    iban: '',
    is_light: false,
    label_user: {
      avatar: {},
      country: '',
      display_name: '',
      public_nick_name: '',
      uuid: ''
    },
    merchant_category_code: '',
    swift_account_number: '',
    swift_bic: '',
    transferwise_account_number: '',
    transferwise_bank_code: ''
  },
  amount_inquired: {
    currency: '',
    value: ''
  },
  amount_responded: {},
  attachment: [
    {
      content_type: '',
      description: '',
      urls: [
        {
          type: '',
          url: ''
        }
      ]
    }
  ],
  counterparty_alias: {},
  created: '',
  credit_scheme_identifier: '',
  description: '',
  eligible_whitelist_id: 0,
  event_id: 0,
  geolocation: {
    altitude: 0,
    latitude: 0,
    longitude: 0,
    radius: 0
  },
  id: 0,
  mandate_identifier: '',
  minimum_age: 0,
  monetary_account_id: 0,
  redirect_url: '',
  request_reference_split_the_bill: [
    {
      id: 0,
      type: ''
    }
  ],
  require_address: '',
  status: '',
  sub_type: '',
  time_expiry: '',
  time_refund_requested: '',
  time_refunded: '',
  time_responded: '',
  type: '',
  updated: '',
  user_refund_requested: {}
});

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}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    address_billing: {
      city: '',
      country: '',
      extra: '',
      house_number: '',
      is_user_address_updated: false,
      mailbox_name: '',
      po_box: '',
      postal_code: '',
      province: '',
      street: ''
    },
    address_shipping: {},
    alias: {
      avatar: {
        anchor_uuid: '',
        image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
        style: '',
        uuid: ''
      },
      bunq_me: {name: '', service: '', type: '', value: ''},
      country: '',
      display_name: '',
      iban: '',
      is_light: false,
      label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
      merchant_category_code: '',
      swift_account_number: '',
      swift_bic: '',
      transferwise_account_number: '',
      transferwise_bank_code: ''
    },
    amount_inquired: {currency: '', value: ''},
    amount_responded: {},
    attachment: [{content_type: '', description: '', urls: [{type: '', url: ''}]}],
    counterparty_alias: {},
    created: '',
    credit_scheme_identifier: '',
    description: '',
    eligible_whitelist_id: 0,
    event_id: 0,
    geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
    id: 0,
    mandate_identifier: '',
    minimum_age: 0,
    monetary_account_id: 0,
    redirect_url: '',
    request_reference_split_the_bill: [{id: 0, type: ''}],
    require_address: '',
    status: '',
    sub_type: '',
    time_expiry: '',
    time_refund_requested: '',
    time_refunded: '',
    time_responded: '',
    type: '',
    updated: '',
    user_refund_requested: {}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"address_billing":{"city":"","country":"","extra":"","house_number":"","is_user_address_updated":false,"mailbox_name":"","po_box":"","postal_code":"","province":"","street":""},"address_shipping":{},"alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"amount_inquired":{"currency":"","value":""},"amount_responded":{},"attachment":[{"content_type":"","description":"","urls":[{"type":"","url":""}]}],"counterparty_alias":{},"created":"","credit_scheme_identifier":"","description":"","eligible_whitelist_id":0,"event_id":0,"geolocation":{"altitude":0,"latitude":0,"longitude":0,"radius":0},"id":0,"mandate_identifier":"","minimum_age":0,"monetary_account_id":0,"redirect_url":"","request_reference_split_the_bill":[{"id":0,"type":""}],"require_address":"","status":"","sub_type":"","time_expiry":"","time_refund_requested":"","time_refunded":"","time_responded":"","type":"","updated":"","user_refund_requested":{}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"address_billing": @{ @"city": @"", @"country": @"", @"extra": @"", @"house_number": @"", @"is_user_address_updated": @NO, @"mailbox_name": @"", @"po_box": @"", @"postal_code": @"", @"province": @"", @"street": @"" },
                              @"address_shipping": @{  },
                              @"alias": @{ @"avatar": @{ @"anchor_uuid": @"", @"image": @[ @{ @"attachment_public_uuid": @"", @"content_type": @"", @"height": @0, @"width": @0 } ], @"style": @"", @"uuid": @"" }, @"bunq_me": @{ @"name": @"", @"service": @"", @"type": @"", @"value": @"" }, @"country": @"", @"display_name": @"", @"iban": @"", @"is_light": @NO, @"label_user": @{ @"avatar": @{  }, @"country": @"", @"display_name": @"", @"public_nick_name": @"", @"uuid": @"" }, @"merchant_category_code": @"", @"swift_account_number": @"", @"swift_bic": @"", @"transferwise_account_number": @"", @"transferwise_bank_code": @"" },
                              @"amount_inquired": @{ @"currency": @"", @"value": @"" },
                              @"amount_responded": @{  },
                              @"attachment": @[ @{ @"content_type": @"", @"description": @"", @"urls": @[ @{ @"type": @"", @"url": @"" } ] } ],
                              @"counterparty_alias": @{  },
                              @"created": @"",
                              @"credit_scheme_identifier": @"",
                              @"description": @"",
                              @"eligible_whitelist_id": @0,
                              @"event_id": @0,
                              @"geolocation": @{ @"altitude": @0, @"latitude": @0, @"longitude": @0, @"radius": @0 },
                              @"id": @0,
                              @"mandate_identifier": @"",
                              @"minimum_age": @0,
                              @"monetary_account_id": @0,
                              @"redirect_url": @"",
                              @"request_reference_split_the_bill": @[ @{ @"id": @0, @"type": @"" } ],
                              @"require_address": @"",
                              @"status": @"",
                              @"sub_type": @"",
                              @"time_expiry": @"",
                              @"time_refund_requested": @"",
                              @"time_refunded": @"",
                              @"time_responded": @"",
                              @"type": @"",
                              @"updated": @"",
                              @"user_refund_requested": @{  } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"content_type\": \"\",\n      \"description\": \"\",\n      \"urls\": [\n        {\n          \"type\": \"\",\n          \"url\": \"\"\n        }\n      ]\n    }\n  ],\n  \"counterparty_alias\": {},\n  \"created\": \"\",\n  \"credit_scheme_identifier\": \"\",\n  \"description\": \"\",\n  \"eligible_whitelist_id\": 0,\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"mandate_identifier\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"require_address\": \"\",\n  \"status\": \"\",\n  \"sub_type\": \"\",\n  \"time_expiry\": \"\",\n  \"time_refund_requested\": \"\",\n  \"time_refunded\": \"\",\n  \"time_responded\": \"\",\n  \"type\": \"\",\n  \"updated\": \"\",\n  \"user_refund_requested\": {}\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'address_billing' => [
        'city' => '',
        'country' => '',
        'extra' => '',
        'house_number' => '',
        'is_user_address_updated' => null,
        'mailbox_name' => '',
        'po_box' => '',
        'postal_code' => '',
        'province' => '',
        'street' => ''
    ],
    'address_shipping' => [
        
    ],
    'alias' => [
        'avatar' => [
                'anchor_uuid' => '',
                'image' => [
                                [
                                                                'attachment_public_uuid' => '',
                                                                'content_type' => '',
                                                                'height' => 0,
                                                                'width' => 0
                                ]
                ],
                'style' => '',
                'uuid' => ''
        ],
        'bunq_me' => [
                'name' => '',
                'service' => '',
                'type' => '',
                'value' => ''
        ],
        'country' => '',
        'display_name' => '',
        'iban' => '',
        'is_light' => null,
        'label_user' => [
                'avatar' => [
                                
                ],
                'country' => '',
                'display_name' => '',
                'public_nick_name' => '',
                'uuid' => ''
        ],
        'merchant_category_code' => '',
        'swift_account_number' => '',
        'swift_bic' => '',
        'transferwise_account_number' => '',
        'transferwise_bank_code' => ''
    ],
    'amount_inquired' => [
        'currency' => '',
        'value' => ''
    ],
    'amount_responded' => [
        
    ],
    'attachment' => [
        [
                'content_type' => '',
                'description' => '',
                'urls' => [
                                [
                                                                'type' => '',
                                                                'url' => ''
                                ]
                ]
        ]
    ],
    'counterparty_alias' => [
        
    ],
    'created' => '',
    'credit_scheme_identifier' => '',
    'description' => '',
    'eligible_whitelist_id' => 0,
    'event_id' => 0,
    'geolocation' => [
        'altitude' => 0,
        'latitude' => 0,
        'longitude' => 0,
        'radius' => 0
    ],
    'id' => 0,
    'mandate_identifier' => '',
    'minimum_age' => 0,
    'monetary_account_id' => 0,
    'redirect_url' => '',
    'request_reference_split_the_bill' => [
        [
                'id' => 0,
                'type' => ''
        ]
    ],
    'require_address' => '',
    'status' => '',
    'sub_type' => '',
    'time_expiry' => '',
    'time_refund_requested' => '',
    'time_refunded' => '',
    'time_responded' => '',
    'type' => '',
    'updated' => '',
    'user_refund_requested' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId', [
  'body' => '{
  "address_billing": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_shipping": {},
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "amount_inquired": {
    "currency": "",
    "value": ""
  },
  "amount_responded": {},
  "attachment": [
    {
      "content_type": "",
      "description": "",
      "urls": [
        {
          "type": "",
          "url": ""
        }
      ]
    }
  ],
  "counterparty_alias": {},
  "created": "",
  "credit_scheme_identifier": "",
  "description": "",
  "eligible_whitelist_id": 0,
  "event_id": 0,
  "geolocation": {
    "altitude": 0,
    "latitude": 0,
    "longitude": 0,
    "radius": 0
  },
  "id": 0,
  "mandate_identifier": "",
  "minimum_age": 0,
  "monetary_account_id": 0,
  "redirect_url": "",
  "request_reference_split_the_bill": [
    {
      "id": 0,
      "type": ""
    }
  ],
  "require_address": "",
  "status": "",
  "sub_type": "",
  "time_expiry": "",
  "time_refund_requested": "",
  "time_refunded": "",
  "time_responded": "",
  "type": "",
  "updated": "",
  "user_refund_requested": {}
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'address_billing' => [
    'city' => '',
    'country' => '',
    'extra' => '',
    'house_number' => '',
    'is_user_address_updated' => null,
    'mailbox_name' => '',
    'po_box' => '',
    'postal_code' => '',
    'province' => '',
    'street' => ''
  ],
  'address_shipping' => [
    
  ],
  'alias' => [
    'avatar' => [
        'anchor_uuid' => '',
        'image' => [
                [
                                'attachment_public_uuid' => '',
                                'content_type' => '',
                                'height' => 0,
                                'width' => 0
                ]
        ],
        'style' => '',
        'uuid' => ''
    ],
    'bunq_me' => [
        'name' => '',
        'service' => '',
        'type' => '',
        'value' => ''
    ],
    'country' => '',
    'display_name' => '',
    'iban' => '',
    'is_light' => null,
    'label_user' => [
        'avatar' => [
                
        ],
        'country' => '',
        'display_name' => '',
        'public_nick_name' => '',
        'uuid' => ''
    ],
    'merchant_category_code' => '',
    'swift_account_number' => '',
    'swift_bic' => '',
    'transferwise_account_number' => '',
    'transferwise_bank_code' => ''
  ],
  'amount_inquired' => [
    'currency' => '',
    'value' => ''
  ],
  'amount_responded' => [
    
  ],
  'attachment' => [
    [
        'content_type' => '',
        'description' => '',
        'urls' => [
                [
                                'type' => '',
                                'url' => ''
                ]
        ]
    ]
  ],
  'counterparty_alias' => [
    
  ],
  'created' => '',
  'credit_scheme_identifier' => '',
  'description' => '',
  'eligible_whitelist_id' => 0,
  'event_id' => 0,
  'geolocation' => [
    'altitude' => 0,
    'latitude' => 0,
    'longitude' => 0,
    'radius' => 0
  ],
  'id' => 0,
  'mandate_identifier' => '',
  'minimum_age' => 0,
  'monetary_account_id' => 0,
  'redirect_url' => '',
  'request_reference_split_the_bill' => [
    [
        'id' => 0,
        'type' => ''
    ]
  ],
  'require_address' => '',
  'status' => '',
  'sub_type' => '',
  'time_expiry' => '',
  'time_refund_requested' => '',
  'time_refunded' => '',
  'time_responded' => '',
  'type' => '',
  'updated' => '',
  'user_refund_requested' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'address_billing' => [
    'city' => '',
    'country' => '',
    'extra' => '',
    'house_number' => '',
    'is_user_address_updated' => null,
    'mailbox_name' => '',
    'po_box' => '',
    'postal_code' => '',
    'province' => '',
    'street' => ''
  ],
  'address_shipping' => [
    
  ],
  'alias' => [
    'avatar' => [
        'anchor_uuid' => '',
        'image' => [
                [
                                'attachment_public_uuid' => '',
                                'content_type' => '',
                                'height' => 0,
                                'width' => 0
                ]
        ],
        'style' => '',
        'uuid' => ''
    ],
    'bunq_me' => [
        'name' => '',
        'service' => '',
        'type' => '',
        'value' => ''
    ],
    'country' => '',
    'display_name' => '',
    'iban' => '',
    'is_light' => null,
    'label_user' => [
        'avatar' => [
                
        ],
        'country' => '',
        'display_name' => '',
        'public_nick_name' => '',
        'uuid' => ''
    ],
    'merchant_category_code' => '',
    'swift_account_number' => '',
    'swift_bic' => '',
    'transferwise_account_number' => '',
    'transferwise_bank_code' => ''
  ],
  'amount_inquired' => [
    'currency' => '',
    'value' => ''
  ],
  'amount_responded' => [
    
  ],
  'attachment' => [
    [
        'content_type' => '',
        'description' => '',
        'urls' => [
                [
                                'type' => '',
                                'url' => ''
                ]
        ]
    ]
  ],
  'counterparty_alias' => [
    
  ],
  'created' => '',
  'credit_scheme_identifier' => '',
  'description' => '',
  'eligible_whitelist_id' => 0,
  'event_id' => 0,
  'geolocation' => [
    'altitude' => 0,
    'latitude' => 0,
    'longitude' => 0,
    'radius' => 0
  ],
  'id' => 0,
  'mandate_identifier' => '',
  'minimum_age' => 0,
  'monetary_account_id' => 0,
  'redirect_url' => '',
  'request_reference_split_the_bill' => [
    [
        'id' => 0,
        'type' => ''
    ]
  ],
  'require_address' => '',
  'status' => '',
  'sub_type' => '',
  'time_expiry' => '',
  'time_refund_requested' => '',
  'time_refunded' => '',
  'time_responded' => '',
  'type' => '',
  'updated' => '',
  'user_refund_requested' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "address_billing": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_shipping": {},
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "amount_inquired": {
    "currency": "",
    "value": ""
  },
  "amount_responded": {},
  "attachment": [
    {
      "content_type": "",
      "description": "",
      "urls": [
        {
          "type": "",
          "url": ""
        }
      ]
    }
  ],
  "counterparty_alias": {},
  "created": "",
  "credit_scheme_identifier": "",
  "description": "",
  "eligible_whitelist_id": 0,
  "event_id": 0,
  "geolocation": {
    "altitude": 0,
    "latitude": 0,
    "longitude": 0,
    "radius": 0
  },
  "id": 0,
  "mandate_identifier": "",
  "minimum_age": 0,
  "monetary_account_id": 0,
  "redirect_url": "",
  "request_reference_split_the_bill": [
    {
      "id": 0,
      "type": ""
    }
  ],
  "require_address": "",
  "status": "",
  "sub_type": "",
  "time_expiry": "",
  "time_refund_requested": "",
  "time_refunded": "",
  "time_responded": "",
  "type": "",
  "updated": "",
  "user_refund_requested": {}
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "address_billing": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_shipping": {},
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "amount_inquired": {
    "currency": "",
    "value": ""
  },
  "amount_responded": {},
  "attachment": [
    {
      "content_type": "",
      "description": "",
      "urls": [
        {
          "type": "",
          "url": ""
        }
      ]
    }
  ],
  "counterparty_alias": {},
  "created": "",
  "credit_scheme_identifier": "",
  "description": "",
  "eligible_whitelist_id": 0,
  "event_id": 0,
  "geolocation": {
    "altitude": 0,
    "latitude": 0,
    "longitude": 0,
    "radius": 0
  },
  "id": 0,
  "mandate_identifier": "",
  "minimum_age": 0,
  "monetary_account_id": 0,
  "redirect_url": "",
  "request_reference_split_the_bill": [
    {
      "id": 0,
      "type": ""
    }
  ],
  "require_address": "",
  "status": "",
  "sub_type": "",
  "time_expiry": "",
  "time_refund_requested": "",
  "time_refunded": "",
  "time_responded": "",
  "type": "",
  "updated": "",
  "user_refund_requested": {}
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"content_type\": \"\",\n      \"description\": \"\",\n      \"urls\": [\n        {\n          \"type\": \"\",\n          \"url\": \"\"\n        }\n      ]\n    }\n  ],\n  \"counterparty_alias\": {},\n  \"created\": \"\",\n  \"credit_scheme_identifier\": \"\",\n  \"description\": \"\",\n  \"eligible_whitelist_id\": 0,\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"mandate_identifier\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"require_address\": \"\",\n  \"status\": \"\",\n  \"sub_type\": \"\",\n  \"time_expiry\": \"\",\n  \"time_refund_requested\": \"\",\n  \"time_refunded\": \"\",\n  \"time_responded\": \"\",\n  \"type\": \"\",\n  \"updated\": \"\",\n  \"user_refund_requested\": {}\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId"

payload = {
    "address_billing": {
        "city": "",
        "country": "",
        "extra": "",
        "house_number": "",
        "is_user_address_updated": False,
        "mailbox_name": "",
        "po_box": "",
        "postal_code": "",
        "province": "",
        "street": ""
    },
    "address_shipping": {},
    "alias": {
        "avatar": {
            "anchor_uuid": "",
            "image": [
                {
                    "attachment_public_uuid": "",
                    "content_type": "",
                    "height": 0,
                    "width": 0
                }
            ],
            "style": "",
            "uuid": ""
        },
        "bunq_me": {
            "name": "",
            "service": "",
            "type": "",
            "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": False,
        "label_user": {
            "avatar": {},
            "country": "",
            "display_name": "",
            "public_nick_name": "",
            "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
    },
    "amount_inquired": {
        "currency": "",
        "value": ""
    },
    "amount_responded": {},
    "attachment": [
        {
            "content_type": "",
            "description": "",
            "urls": [
                {
                    "type": "",
                    "url": ""
                }
            ]
        }
    ],
    "counterparty_alias": {},
    "created": "",
    "credit_scheme_identifier": "",
    "description": "",
    "eligible_whitelist_id": 0,
    "event_id": 0,
    "geolocation": {
        "altitude": 0,
        "latitude": 0,
        "longitude": 0,
        "radius": 0
    },
    "id": 0,
    "mandate_identifier": "",
    "minimum_age": 0,
    "monetary_account_id": 0,
    "redirect_url": "",
    "request_reference_split_the_bill": [
        {
            "id": 0,
            "type": ""
        }
    ],
    "require_address": "",
    "status": "",
    "sub_type": "",
    "time_expiry": "",
    "time_refund_requested": "",
    "time_refunded": "",
    "time_responded": "",
    "type": "",
    "updated": "",
    "user_refund_requested": {}
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId"

payload <- "{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"content_type\": \"\",\n      \"description\": \"\",\n      \"urls\": [\n        {\n          \"type\": \"\",\n          \"url\": \"\"\n        }\n      ]\n    }\n  ],\n  \"counterparty_alias\": {},\n  \"created\": \"\",\n  \"credit_scheme_identifier\": \"\",\n  \"description\": \"\",\n  \"eligible_whitelist_id\": 0,\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"mandate_identifier\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"require_address\": \"\",\n  \"status\": \"\",\n  \"sub_type\": \"\",\n  \"time_expiry\": \"\",\n  \"time_refund_requested\": \"\",\n  \"time_refunded\": \"\",\n  \"time_responded\": \"\",\n  \"type\": \"\",\n  \"updated\": \"\",\n  \"user_refund_requested\": {}\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"content_type\": \"\",\n      \"description\": \"\",\n      \"urls\": [\n        {\n          \"type\": \"\",\n          \"url\": \"\"\n        }\n      ]\n    }\n  ],\n  \"counterparty_alias\": {},\n  \"created\": \"\",\n  \"credit_scheme_identifier\": \"\",\n  \"description\": \"\",\n  \"eligible_whitelist_id\": 0,\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"mandate_identifier\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"require_address\": \"\",\n  \"status\": \"\",\n  \"sub_type\": \"\",\n  \"time_expiry\": \"\",\n  \"time_refund_requested\": \"\",\n  \"time_refunded\": \"\",\n  \"time_responded\": \"\",\n  \"type\": \"\",\n  \"updated\": \"\",\n  \"user_refund_requested\": {}\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"address_billing\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_shipping\": {},\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_inquired\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_responded\": {},\n  \"attachment\": [\n    {\n      \"content_type\": \"\",\n      \"description\": \"\",\n      \"urls\": [\n        {\n          \"type\": \"\",\n          \"url\": \"\"\n        }\n      ]\n    }\n  ],\n  \"counterparty_alias\": {},\n  \"created\": \"\",\n  \"credit_scheme_identifier\": \"\",\n  \"description\": \"\",\n  \"eligible_whitelist_id\": 0,\n  \"event_id\": 0,\n  \"geolocation\": {\n    \"altitude\": 0,\n    \"latitude\": 0,\n    \"longitude\": 0,\n    \"radius\": 0\n  },\n  \"id\": 0,\n  \"mandate_identifier\": \"\",\n  \"minimum_age\": 0,\n  \"monetary_account_id\": 0,\n  \"redirect_url\": \"\",\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"require_address\": \"\",\n  \"status\": \"\",\n  \"sub_type\": \"\",\n  \"time_expiry\": \"\",\n  \"time_refund_requested\": \"\",\n  \"time_refunded\": \"\",\n  \"time_responded\": \"\",\n  \"type\": \"\",\n  \"updated\": \"\",\n  \"user_refund_requested\": {}\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId";

    let payload = json!({
        "address_billing": json!({
            "city": "",
            "country": "",
            "extra": "",
            "house_number": "",
            "is_user_address_updated": false,
            "mailbox_name": "",
            "po_box": "",
            "postal_code": "",
            "province": "",
            "street": ""
        }),
        "address_shipping": json!({}),
        "alias": json!({
            "avatar": json!({
                "anchor_uuid": "",
                "image": (
                    json!({
                        "attachment_public_uuid": "",
                        "content_type": "",
                        "height": 0,
                        "width": 0
                    })
                ),
                "style": "",
                "uuid": ""
            }),
            "bunq_me": json!({
                "name": "",
                "service": "",
                "type": "",
                "value": ""
            }),
            "country": "",
            "display_name": "",
            "iban": "",
            "is_light": false,
            "label_user": json!({
                "avatar": json!({}),
                "country": "",
                "display_name": "",
                "public_nick_name": "",
                "uuid": ""
            }),
            "merchant_category_code": "",
            "swift_account_number": "",
            "swift_bic": "",
            "transferwise_account_number": "",
            "transferwise_bank_code": ""
        }),
        "amount_inquired": json!({
            "currency": "",
            "value": ""
        }),
        "amount_responded": json!({}),
        "attachment": (
            json!({
                "content_type": "",
                "description": "",
                "urls": (
                    json!({
                        "type": "",
                        "url": ""
                    })
                )
            })
        ),
        "counterparty_alias": json!({}),
        "created": "",
        "credit_scheme_identifier": "",
        "description": "",
        "eligible_whitelist_id": 0,
        "event_id": 0,
        "geolocation": json!({
            "altitude": 0,
            "latitude": 0,
            "longitude": 0,
            "radius": 0
        }),
        "id": 0,
        "mandate_identifier": "",
        "minimum_age": 0,
        "monetary_account_id": 0,
        "redirect_url": "",
        "request_reference_split_the_bill": (
            json!({
                "id": 0,
                "type": ""
            })
        ),
        "require_address": "",
        "status": "",
        "sub_type": "",
        "time_expiry": "",
        "time_refund_requested": "",
        "time_refunded": "",
        "time_responded": "",
        "type": "",
        "updated": "",
        "user_refund_requested": json!({})
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "address_billing": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_shipping": {},
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "amount_inquired": {
    "currency": "",
    "value": ""
  },
  "amount_responded": {},
  "attachment": [
    {
      "content_type": "",
      "description": "",
      "urls": [
        {
          "type": "",
          "url": ""
        }
      ]
    }
  ],
  "counterparty_alias": {},
  "created": "",
  "credit_scheme_identifier": "",
  "description": "",
  "eligible_whitelist_id": 0,
  "event_id": 0,
  "geolocation": {
    "altitude": 0,
    "latitude": 0,
    "longitude": 0,
    "radius": 0
  },
  "id": 0,
  "mandate_identifier": "",
  "minimum_age": 0,
  "monetary_account_id": 0,
  "redirect_url": "",
  "request_reference_split_the_bill": [
    {
      "id": 0,
      "type": ""
    }
  ],
  "require_address": "",
  "status": "",
  "sub_type": "",
  "time_expiry": "",
  "time_refund_requested": "",
  "time_refunded": "",
  "time_responded": "",
  "type": "",
  "updated": "",
  "user_refund_requested": {}
}'
echo '{
  "address_billing": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_shipping": {},
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "amount_inquired": {
    "currency": "",
    "value": ""
  },
  "amount_responded": {},
  "attachment": [
    {
      "content_type": "",
      "description": "",
      "urls": [
        {
          "type": "",
          "url": ""
        }
      ]
    }
  ],
  "counterparty_alias": {},
  "created": "",
  "credit_scheme_identifier": "",
  "description": "",
  "eligible_whitelist_id": 0,
  "event_id": 0,
  "geolocation": {
    "altitude": 0,
    "latitude": 0,
    "longitude": 0,
    "radius": 0
  },
  "id": 0,
  "mandate_identifier": "",
  "minimum_age": 0,
  "monetary_account_id": 0,
  "redirect_url": "",
  "request_reference_split_the_bill": [
    {
      "id": 0,
      "type": ""
    }
  ],
  "require_address": "",
  "status": "",
  "sub_type": "",
  "time_expiry": "",
  "time_refund_requested": "",
  "time_refunded": "",
  "time_responded": "",
  "type": "",
  "updated": "",
  "user_refund_requested": {}
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "address_billing": {\n    "city": "",\n    "country": "",\n    "extra": "",\n    "house_number": "",\n    "is_user_address_updated": false,\n    "mailbox_name": "",\n    "po_box": "",\n    "postal_code": "",\n    "province": "",\n    "street": ""\n  },\n  "address_shipping": {},\n  "alias": {\n    "avatar": {\n      "anchor_uuid": "",\n      "image": [\n        {\n          "attachment_public_uuid": "",\n          "content_type": "",\n          "height": 0,\n          "width": 0\n        }\n      ],\n      "style": "",\n      "uuid": ""\n    },\n    "bunq_me": {\n      "name": "",\n      "service": "",\n      "type": "",\n      "value": ""\n    },\n    "country": "",\n    "display_name": "",\n    "iban": "",\n    "is_light": false,\n    "label_user": {\n      "avatar": {},\n      "country": "",\n      "display_name": "",\n      "public_nick_name": "",\n      "uuid": ""\n    },\n    "merchant_category_code": "",\n    "swift_account_number": "",\n    "swift_bic": "",\n    "transferwise_account_number": "",\n    "transferwise_bank_code": ""\n  },\n  "amount_inquired": {\n    "currency": "",\n    "value": ""\n  },\n  "amount_responded": {},\n  "attachment": [\n    {\n      "content_type": "",\n      "description": "",\n      "urls": [\n        {\n          "type": "",\n          "url": ""\n        }\n      ]\n    }\n  ],\n  "counterparty_alias": {},\n  "created": "",\n  "credit_scheme_identifier": "",\n  "description": "",\n  "eligible_whitelist_id": 0,\n  "event_id": 0,\n  "geolocation": {\n    "altitude": 0,\n    "latitude": 0,\n    "longitude": 0,\n    "radius": 0\n  },\n  "id": 0,\n  "mandate_identifier": "",\n  "minimum_age": 0,\n  "monetary_account_id": 0,\n  "redirect_url": "",\n  "request_reference_split_the_bill": [\n    {\n      "id": 0,\n      "type": ""\n    }\n  ],\n  "require_address": "",\n  "status": "",\n  "sub_type": "",\n  "time_expiry": "",\n  "time_refund_requested": "",\n  "time_refunded": "",\n  "time_responded": "",\n  "type": "",\n  "updated": "",\n  "user_refund_requested": {}\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "address_billing": [
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  ],
  "address_shipping": [],
  "alias": [
    "avatar": [
      "anchor_uuid": "",
      "image": [
        [
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        ]
      ],
      "style": "",
      "uuid": ""
    ],
    "bunq_me": [
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    ],
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": [
      "avatar": [],
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    ],
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  ],
  "amount_inquired": [
    "currency": "",
    "value": ""
  ],
  "amount_responded": [],
  "attachment": [
    [
      "content_type": "",
      "description": "",
      "urls": [
        [
          "type": "",
          "url": ""
        ]
      ]
    ]
  ],
  "counterparty_alias": [],
  "created": "",
  "credit_scheme_identifier": "",
  "description": "",
  "eligible_whitelist_id": 0,
  "event_id": 0,
  "geolocation": [
    "altitude": 0,
    "latitude": 0,
    "longitude": 0,
    "radius": 0
  ],
  "id": 0,
  "mandate_identifier": "",
  "minimum_age": 0,
  "monetary_account_id": 0,
  "redirect_url": "",
  "request_reference_split_the_bill": [
    [
      "id": 0,
      "type": ""
    ]
  ],
  "require_address": "",
  "status": "",
  "sub_type": "",
  "time_expiry": "",
  "time_refund_requested": "",
  "time_refunded": "",
  "time_responded": "",
  "type": "",
  "updated": "",
  "user_refund_requested": []
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/request-response/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_Reward_for_User
{{baseUrl}}/user/:userID/reward
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/reward");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/reward" {:headers {:user-agent ""
                                                                         :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/reward"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/reward"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/reward");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/reward"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/reward HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/reward")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/reward"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/reward")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/reward")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/reward');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/reward',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/reward';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/reward',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/reward")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/reward',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/reward',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/reward');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/reward',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/reward';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/reward"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/reward" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/reward",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/reward', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/reward');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/reward');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/reward' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/reward' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/reward", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/reward"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/reward"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/reward")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/reward') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/reward";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/reward \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/reward \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/reward
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/reward")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_Reward_for_User
{{baseUrl}}/user/:userID/reward/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/reward/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/reward/:itemId" {:headers {:user-agent ""
                                                                                 :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/reward/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/reward/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/reward/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/reward/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/reward/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/reward/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/reward/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/reward/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/reward/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/reward/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/reward/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/reward/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/reward/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/reward/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/reward/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/reward/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/reward/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/reward/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/reward/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/reward/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/reward/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/reward/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/reward/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/reward/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/reward/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/reward/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/reward/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/reward/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/reward/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/reward/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/reward/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/reward/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/reward/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/reward/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/reward/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/reward/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/reward/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_RewardRecipient_for_User
{{baseUrl}}/user/:userID/reward-recipient
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/reward-recipient");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/reward-recipient" {:headers {:user-agent ""
                                                                                   :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/reward-recipient"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/reward-recipient"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/reward-recipient");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/reward-recipient"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/reward-recipient HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/reward-recipient")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/reward-recipient"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/reward-recipient")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/reward-recipient")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/reward-recipient');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/reward-recipient',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/reward-recipient';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/reward-recipient',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/reward-recipient")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/reward-recipient',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/reward-recipient',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/reward-recipient');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/reward-recipient',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/reward-recipient';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/reward-recipient"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/reward-recipient" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/reward-recipient",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/reward-recipient', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/reward-recipient');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/reward-recipient');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/reward-recipient' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/reward-recipient' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/reward-recipient", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/reward-recipient"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/reward-recipient"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/reward-recipient")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/reward-recipient') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/reward-recipient";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/reward-recipient \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/reward-recipient \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/reward-recipient
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/reward-recipient")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_RewardRecipient_for_User
{{baseUrl}}/user/:userID/reward-recipient/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/reward-recipient/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/reward-recipient/:itemId" {:headers {:user-agent ""
                                                                                           :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/reward-recipient/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/reward-recipient/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/reward-recipient/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/reward-recipient/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/reward-recipient/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/reward-recipient/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/reward-recipient/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/reward-recipient/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/reward-recipient/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/reward-recipient/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/reward-recipient/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/reward-recipient/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/reward-recipient/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/reward-recipient/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/reward-recipient/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/reward-recipient/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/reward-recipient/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/reward-recipient/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/reward-recipient/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/reward-recipient/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/reward-recipient/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/reward-recipient/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/reward-recipient/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/reward-recipient/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/reward-recipient/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/reward-recipient/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/reward-recipient/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/reward-recipient/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/reward-recipient/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/reward-recipient/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/reward-recipient/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/reward-recipient/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/reward-recipient/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/reward-recipient/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/reward-recipient/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/reward-recipient/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/reward-recipient/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_RewardSender_for_User
{{baseUrl}}/user/:userID/reward-sender
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/reward-sender");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/reward-sender" {:headers {:user-agent ""
                                                                                :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/reward-sender"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/reward-sender"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/reward-sender");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/reward-sender"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/reward-sender HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/reward-sender")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/reward-sender"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/reward-sender")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/reward-sender")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/reward-sender');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/reward-sender',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/reward-sender';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/reward-sender',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/reward-sender")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/reward-sender',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/reward-sender',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/reward-sender');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/reward-sender',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/reward-sender';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/reward-sender"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/reward-sender" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/reward-sender",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/reward-sender', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/reward-sender');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/reward-sender');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/reward-sender' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/reward-sender' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/reward-sender", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/reward-sender"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/reward-sender"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/reward-sender")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/reward-sender') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/reward-sender";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/reward-sender \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/reward-sender \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/reward-sender
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/reward-sender")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_RewardSender_for_User
{{baseUrl}}/user/:userID/reward-sender/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/reward-sender/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/reward-sender/:itemId" {:headers {:user-agent ""
                                                                                        :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/reward-sender/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/reward-sender/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/reward-sender/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/reward-sender/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/reward-sender/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/reward-sender/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/reward-sender/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/reward-sender/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/reward-sender/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/reward-sender/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/reward-sender/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/reward-sender/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/reward-sender/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/reward-sender/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/reward-sender/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/reward-sender/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/reward-sender/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/reward-sender/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/reward-sender/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/reward-sender/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/reward-sender/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/reward-sender/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/reward-sender/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/reward-sender/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/reward-sender/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/reward-sender/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/reward-sender/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/reward-sender/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/reward-sender/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/reward-sender/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/reward-sender/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/reward-sender/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/reward-sender/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/reward-sender/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/reward-sender/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/reward-sender/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/reward-sender/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_SandboxUserCompany
{{baseUrl}}/sandbox-user-company
HEADERS

User-Agent
X-Bunq-Client-Authentication
BODY json

{}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/sandbox-user-company");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/sandbox-user-company" {:headers {:user-agent ""
                                                                           :x-bunq-client-authentication ""}
                                                                 :content-type :json})
require "http/client"

url = "{{baseUrl}}/sandbox-user-company"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/sandbox-user-company"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/sandbox-user-company");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/sandbox-user-company"

	payload := strings.NewReader("{}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/sandbox-user-company HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 2

{}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/sandbox-user-company")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/sandbox-user-company"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/sandbox-user-company")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/sandbox-user-company")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{}")
  .asString();
const data = JSON.stringify({});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/sandbox-user-company');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/sandbox-user-company',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/sandbox-user-company';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/sandbox-user-company',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{}")
val request = Request.Builder()
  .url("{{baseUrl}}/sandbox-user-company")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/sandbox-user-company',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/sandbox-user-company',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/sandbox-user-company');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/sandbox-user-company',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/sandbox-user-company';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{  };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/sandbox-user-company"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/sandbox-user-company" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/sandbox-user-company",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/sandbox-user-company', [
  'body' => '{}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/sandbox-user-company');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  
]));
$request->setRequestUrl('{{baseUrl}}/sandbox-user-company');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/sandbox-user-company' -Method POST -Headers $headers -ContentType 'application/json' -Body '{}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/sandbox-user-company' -Method POST -Headers $headers -ContentType 'application/json' -Body '{}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/sandbox-user-company", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/sandbox-user-company"

payload = {}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/sandbox-user-company"

payload <- "{}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/sandbox-user-company")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/sandbox-user-company') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/sandbox-user-company";

    let payload = json!({});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/sandbox-user-company \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{}'
echo '{}' |  \
  http POST {{baseUrl}}/sandbox-user-company \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{}' \
  --output-document \
  - {{baseUrl}}/sandbox-user-company
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/sandbox-user-company")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_SandboxUserPerson
{{baseUrl}}/sandbox-user-person
HEADERS

User-Agent
X-Bunq-Client-Authentication
BODY json

{}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/sandbox-user-person");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/sandbox-user-person" {:headers {:user-agent ""
                                                                          :x-bunq-client-authentication ""}
                                                                :content-type :json})
require "http/client"

url = "{{baseUrl}}/sandbox-user-person"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/sandbox-user-person"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/sandbox-user-person");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/sandbox-user-person"

	payload := strings.NewReader("{}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/sandbox-user-person HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 2

{}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/sandbox-user-person")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/sandbox-user-person"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/sandbox-user-person")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/sandbox-user-person")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{}")
  .asString();
const data = JSON.stringify({});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/sandbox-user-person');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/sandbox-user-person',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/sandbox-user-person';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/sandbox-user-person',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{}")
val request = Request.Builder()
  .url("{{baseUrl}}/sandbox-user-person")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/sandbox-user-person',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/sandbox-user-person',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/sandbox-user-person');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/sandbox-user-person',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/sandbox-user-person';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{  };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/sandbox-user-person"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/sandbox-user-person" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/sandbox-user-person",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/sandbox-user-person', [
  'body' => '{}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/sandbox-user-person');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  
]));
$request->setRequestUrl('{{baseUrl}}/sandbox-user-person');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/sandbox-user-person' -Method POST -Headers $headers -ContentType 'application/json' -Body '{}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/sandbox-user-person' -Method POST -Headers $headers -ContentType 'application/json' -Body '{}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/sandbox-user-person", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/sandbox-user-person"

payload = {}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/sandbox-user-person"

payload <- "{}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/sandbox-user-person")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/sandbox-user-person') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/sandbox-user-person";

    let payload = json!({});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/sandbox-user-person \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{}'
echo '{}' |  \
  http POST {{baseUrl}}/sandbox-user-person \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{}' \
  --output-document \
  - {{baseUrl}}/sandbox-user-person
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/sandbox-user-person")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_Schedule_for_User
{{baseUrl}}/user/:userID/schedule
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/schedule");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/schedule" {:headers {:user-agent ""
                                                                           :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/schedule"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/schedule"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/schedule");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/schedule"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/schedule HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/schedule")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/schedule"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/schedule")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/schedule")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/schedule');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/schedule',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/schedule';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/schedule',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/schedule")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/schedule',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/schedule',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/schedule');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/schedule',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/schedule';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/schedule"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/schedule" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/schedule",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/schedule', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/schedule');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/schedule');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/schedule' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/schedule' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/schedule", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/schedule"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/schedule"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/schedule")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/schedule') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/schedule";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/schedule \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/schedule \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/schedule
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/schedule")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_Schedule_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule" {:headers {:user-agent ""
                                                                                                                :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_Schedule_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:itemId" {:headers {:user-agent ""
                                                                                                                        :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_ScheduleInstance_for_User_MonetaryAccount_Schedule
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
scheduleID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance" {:headers {:user-agent ""
                                                                                                                                              :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_ScheduleInstance_for_User_MonetaryAccount_Schedule
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
scheduleID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId" {:headers {:user-agent ""
                                                                                                                                                      :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_ScheduleInstance_for_User_MonetaryAccount_Schedule
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
scheduleID
itemId
BODY json

{
  "error_message": [],
  "request_reference_split_the_bill": [
    {
      "id": 0,
      "type": ""
    }
  ],
  "result_object": {
    "Payment": {
      "address_billing": {
        "city": "",
        "country": "",
        "extra": "",
        "house_number": "",
        "is_user_address_updated": false,
        "mailbox_name": "",
        "po_box": "",
        "postal_code": "",
        "province": "",
        "street": ""
      },
      "address_shipping": {},
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "allow_bunqto": false,
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "balance_after_mutation": {},
      "batch_id": 0,
      "bunqto_expiry": "",
      "bunqto_share_url": "",
      "bunqto_status": "",
      "bunqto_sub_status": "",
      "bunqto_time_responded": "",
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "geolocation": {
        "altitude": 0,
        "latitude": 0,
        "longitude": 0,
        "radius": 0
      },
      "id": 0,
      "merchant_reference": "",
      "monetary_account_id": 0,
      "payment_auto_allocate_instance": {
        "created": "",
        "error_message": [],
        "id": 0,
        "payment_auto_allocate_id": 0,
        "payment_batch": {
          "payments": {
            "Payment": []
          }
        },
        "payment_id": 0,
        "status": "",
        "updated": ""
      },
      "request_reference_split_the_bill": [
        {}
      ],
      "scheduled_id": 0,
      "sub_type": "",
      "type": "",
      "updated": ""
    },
    "PaymentBatch": {}
  },
  "scheduled_object": {
    "Payment": {},
    "PaymentBatch": {}
  },
  "state": "",
  "time_end": "",
  "time_start": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"error_message\": [],\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"result_object\": {\n    \"Payment\": {\n      \"address_billing\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"address_shipping\": {},\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"balance_after_mutation\": {},\n      \"batch_id\": 0,\n      \"bunqto_expiry\": \"\",\n      \"bunqto_share_url\": \"\",\n      \"bunqto_status\": \"\",\n      \"bunqto_sub_status\": \"\",\n      \"bunqto_time_responded\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"geolocation\": {\n        \"altitude\": 0,\n        \"latitude\": 0,\n        \"longitude\": 0,\n        \"radius\": 0\n      },\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"monetary_account_id\": 0,\n      \"payment_auto_allocate_instance\": {\n        \"created\": \"\",\n        \"error_message\": [],\n        \"id\": 0,\n        \"payment_auto_allocate_id\": 0,\n        \"payment_batch\": {\n          \"payments\": {\n            \"Payment\": []\n          }\n        },\n        \"payment_id\": 0,\n        \"status\": \"\",\n        \"updated\": \"\"\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"scheduled_id\": 0,\n      \"sub_type\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\"\n    },\n    \"PaymentBatch\": {}\n  },\n  \"scheduled_object\": {\n    \"Payment\": {},\n    \"PaymentBatch\": {}\n  },\n  \"state\": \"\",\n  \"time_end\": \"\",\n  \"time_start\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId" {:headers {:user-agent ""
                                                                                                                                                      :x-bunq-client-authentication ""}
                                                                                                                                            :content-type :json
                                                                                                                                            :form-params {:error_message []
                                                                                                                                                          :request_reference_split_the_bill [{:id 0
                                                                                                                                                                                              :type ""}]
                                                                                                                                                          :result_object {:Payment {:address_billing {:city ""
                                                                                                                                                                                                      :country ""
                                                                                                                                                                                                      :extra ""
                                                                                                                                                                                                      :house_number ""
                                                                                                                                                                                                      :is_user_address_updated false
                                                                                                                                                                                                      :mailbox_name ""
                                                                                                                                                                                                      :po_box ""
                                                                                                                                                                                                      :postal_code ""
                                                                                                                                                                                                      :province ""
                                                                                                                                                                                                      :street ""}
                                                                                                                                                                                    :address_shipping {}
                                                                                                                                                                                    :alias {:avatar {:anchor_uuid ""
                                                                                                                                                                                                     :image [{:attachment_public_uuid ""
                                                                                                                                                                                                              :content_type ""
                                                                                                                                                                                                              :height 0
                                                                                                                                                                                                              :width 0}]
                                                                                                                                                                                                     :style ""
                                                                                                                                                                                                     :uuid ""}
                                                                                                                                                                                            :bunq_me {:name ""
                                                                                                                                                                                                      :service ""
                                                                                                                                                                                                      :type ""
                                                                                                                                                                                                      :value ""}
                                                                                                                                                                                            :country ""
                                                                                                                                                                                            :display_name ""
                                                                                                                                                                                            :iban ""
                                                                                                                                                                                            :is_light false
                                                                                                                                                                                            :label_user {:avatar {}
                                                                                                                                                                                                         :country ""
                                                                                                                                                                                                         :display_name ""
                                                                                                                                                                                                         :public_nick_name ""
                                                                                                                                                                                                         :uuid ""}
                                                                                                                                                                                            :merchant_category_code ""
                                                                                                                                                                                            :swift_account_number ""
                                                                                                                                                                                            :swift_bic ""
                                                                                                                                                                                            :transferwise_account_number ""
                                                                                                                                                                                            :transferwise_bank_code ""}
                                                                                                                                                                                    :allow_bunqto false
                                                                                                                                                                                    :amount {:currency ""
                                                                                                                                                                                             :value ""}
                                                                                                                                                                                    :attachment [{:id 0
                                                                                                                                                                                                  :monetary_account_id 0}]
                                                                                                                                                                                    :balance_after_mutation {}
                                                                                                                                                                                    :batch_id 0
                                                                                                                                                                                    :bunqto_expiry ""
                                                                                                                                                                                    :bunqto_share_url ""
                                                                                                                                                                                    :bunqto_status ""
                                                                                                                                                                                    :bunqto_sub_status ""
                                                                                                                                                                                    :bunqto_time_responded ""
                                                                                                                                                                                    :counterparty_alias {}
                                                                                                                                                                                    :created ""
                                                                                                                                                                                    :description ""
                                                                                                                                                                                    :geolocation {:altitude 0
                                                                                                                                                                                                  :latitude 0
                                                                                                                                                                                                  :longitude 0
                                                                                                                                                                                                  :radius 0}
                                                                                                                                                                                    :id 0
                                                                                                                                                                                    :merchant_reference ""
                                                                                                                                                                                    :monetary_account_id 0
                                                                                                                                                                                    :payment_auto_allocate_instance {:created ""
                                                                                                                                                                                                                     :error_message []
                                                                                                                                                                                                                     :id 0
                                                                                                                                                                                                                     :payment_auto_allocate_id 0
                                                                                                                                                                                                                     :payment_batch {:payments {:Payment []}}
                                                                                                                                                                                                                     :payment_id 0
                                                                                                                                                                                                                     :status ""
                                                                                                                                                                                                                     :updated ""}
                                                                                                                                                                                    :request_reference_split_the_bill [{}]
                                                                                                                                                                                    :scheduled_id 0
                                                                                                                                                                                    :sub_type ""
                                                                                                                                                                                    :type ""
                                                                                                                                                                                    :updated ""}
                                                                                                                                                                          :PaymentBatch {}}
                                                                                                                                                          :scheduled_object {:Payment {}
                                                                                                                                                                             :PaymentBatch {}}
                                                                                                                                                          :state ""
                                                                                                                                                          :time_end ""
                                                                                                                                                          :time_start ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"error_message\": [],\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"result_object\": {\n    \"Payment\": {\n      \"address_billing\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"address_shipping\": {},\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"balance_after_mutation\": {},\n      \"batch_id\": 0,\n      \"bunqto_expiry\": \"\",\n      \"bunqto_share_url\": \"\",\n      \"bunqto_status\": \"\",\n      \"bunqto_sub_status\": \"\",\n      \"bunqto_time_responded\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"geolocation\": {\n        \"altitude\": 0,\n        \"latitude\": 0,\n        \"longitude\": 0,\n        \"radius\": 0\n      },\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"monetary_account_id\": 0,\n      \"payment_auto_allocate_instance\": {\n        \"created\": \"\",\n        \"error_message\": [],\n        \"id\": 0,\n        \"payment_auto_allocate_id\": 0,\n        \"payment_batch\": {\n          \"payments\": {\n            \"Payment\": []\n          }\n        },\n        \"payment_id\": 0,\n        \"status\": \"\",\n        \"updated\": \"\"\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"scheduled_id\": 0,\n      \"sub_type\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\"\n    },\n    \"PaymentBatch\": {}\n  },\n  \"scheduled_object\": {\n    \"Payment\": {},\n    \"PaymentBatch\": {}\n  },\n  \"state\": \"\",\n  \"time_end\": \"\",\n  \"time_start\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"error_message\": [],\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"result_object\": {\n    \"Payment\": {\n      \"address_billing\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"address_shipping\": {},\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"balance_after_mutation\": {},\n      \"batch_id\": 0,\n      \"bunqto_expiry\": \"\",\n      \"bunqto_share_url\": \"\",\n      \"bunqto_status\": \"\",\n      \"bunqto_sub_status\": \"\",\n      \"bunqto_time_responded\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"geolocation\": {\n        \"altitude\": 0,\n        \"latitude\": 0,\n        \"longitude\": 0,\n        \"radius\": 0\n      },\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"monetary_account_id\": 0,\n      \"payment_auto_allocate_instance\": {\n        \"created\": \"\",\n        \"error_message\": [],\n        \"id\": 0,\n        \"payment_auto_allocate_id\": 0,\n        \"payment_batch\": {\n          \"payments\": {\n            \"Payment\": []\n          }\n        },\n        \"payment_id\": 0,\n        \"status\": \"\",\n        \"updated\": \"\"\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"scheduled_id\": 0,\n      \"sub_type\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\"\n    },\n    \"PaymentBatch\": {}\n  },\n  \"scheduled_object\": {\n    \"Payment\": {},\n    \"PaymentBatch\": {}\n  },\n  \"state\": \"\",\n  \"time_end\": \"\",\n  \"time_start\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"error_message\": [],\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"result_object\": {\n    \"Payment\": {\n      \"address_billing\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"address_shipping\": {},\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"balance_after_mutation\": {},\n      \"batch_id\": 0,\n      \"bunqto_expiry\": \"\",\n      \"bunqto_share_url\": \"\",\n      \"bunqto_status\": \"\",\n      \"bunqto_sub_status\": \"\",\n      \"bunqto_time_responded\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"geolocation\": {\n        \"altitude\": 0,\n        \"latitude\": 0,\n        \"longitude\": 0,\n        \"radius\": 0\n      },\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"monetary_account_id\": 0,\n      \"payment_auto_allocate_instance\": {\n        \"created\": \"\",\n        \"error_message\": [],\n        \"id\": 0,\n        \"payment_auto_allocate_id\": 0,\n        \"payment_batch\": {\n          \"payments\": {\n            \"Payment\": []\n          }\n        },\n        \"payment_id\": 0,\n        \"status\": \"\",\n        \"updated\": \"\"\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"scheduled_id\": 0,\n      \"sub_type\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\"\n    },\n    \"PaymentBatch\": {}\n  },\n  \"scheduled_object\": {\n    \"Payment\": {},\n    \"PaymentBatch\": {}\n  },\n  \"state\": \"\",\n  \"time_end\": \"\",\n  \"time_start\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId"

	payload := strings.NewReader("{\n  \"error_message\": [],\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"result_object\": {\n    \"Payment\": {\n      \"address_billing\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"address_shipping\": {},\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"balance_after_mutation\": {},\n      \"batch_id\": 0,\n      \"bunqto_expiry\": \"\",\n      \"bunqto_share_url\": \"\",\n      \"bunqto_status\": \"\",\n      \"bunqto_sub_status\": \"\",\n      \"bunqto_time_responded\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"geolocation\": {\n        \"altitude\": 0,\n        \"latitude\": 0,\n        \"longitude\": 0,\n        \"radius\": 0\n      },\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"monetary_account_id\": 0,\n      \"payment_auto_allocate_instance\": {\n        \"created\": \"\",\n        \"error_message\": [],\n        \"id\": 0,\n        \"payment_auto_allocate_id\": 0,\n        \"payment_batch\": {\n          \"payments\": {\n            \"Payment\": []\n          }\n        },\n        \"payment_id\": 0,\n        \"status\": \"\",\n        \"updated\": \"\"\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"scheduled_id\": 0,\n      \"sub_type\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\"\n    },\n    \"PaymentBatch\": {}\n  },\n  \"scheduled_object\": {\n    \"Payment\": {},\n    \"PaymentBatch\": {}\n  },\n  \"state\": \"\",\n  \"time_end\": \"\",\n  \"time_start\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 2692

{
  "error_message": [],
  "request_reference_split_the_bill": [
    {
      "id": 0,
      "type": ""
    }
  ],
  "result_object": {
    "Payment": {
      "address_billing": {
        "city": "",
        "country": "",
        "extra": "",
        "house_number": "",
        "is_user_address_updated": false,
        "mailbox_name": "",
        "po_box": "",
        "postal_code": "",
        "province": "",
        "street": ""
      },
      "address_shipping": {},
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "allow_bunqto": false,
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "balance_after_mutation": {},
      "batch_id": 0,
      "bunqto_expiry": "",
      "bunqto_share_url": "",
      "bunqto_status": "",
      "bunqto_sub_status": "",
      "bunqto_time_responded": "",
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "geolocation": {
        "altitude": 0,
        "latitude": 0,
        "longitude": 0,
        "radius": 0
      },
      "id": 0,
      "merchant_reference": "",
      "monetary_account_id": 0,
      "payment_auto_allocate_instance": {
        "created": "",
        "error_message": [],
        "id": 0,
        "payment_auto_allocate_id": 0,
        "payment_batch": {
          "payments": {
            "Payment": []
          }
        },
        "payment_id": 0,
        "status": "",
        "updated": ""
      },
      "request_reference_split_the_bill": [
        {}
      ],
      "scheduled_id": 0,
      "sub_type": "",
      "type": "",
      "updated": ""
    },
    "PaymentBatch": {}
  },
  "scheduled_object": {
    "Payment": {},
    "PaymentBatch": {}
  },
  "state": "",
  "time_end": "",
  "time_start": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"error_message\": [],\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"result_object\": {\n    \"Payment\": {\n      \"address_billing\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"address_shipping\": {},\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"balance_after_mutation\": {},\n      \"batch_id\": 0,\n      \"bunqto_expiry\": \"\",\n      \"bunqto_share_url\": \"\",\n      \"bunqto_status\": \"\",\n      \"bunqto_sub_status\": \"\",\n      \"bunqto_time_responded\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"geolocation\": {\n        \"altitude\": 0,\n        \"latitude\": 0,\n        \"longitude\": 0,\n        \"radius\": 0\n      },\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"monetary_account_id\": 0,\n      \"payment_auto_allocate_instance\": {\n        \"created\": \"\",\n        \"error_message\": [],\n        \"id\": 0,\n        \"payment_auto_allocate_id\": 0,\n        \"payment_batch\": {\n          \"payments\": {\n            \"Payment\": []\n          }\n        },\n        \"payment_id\": 0,\n        \"status\": \"\",\n        \"updated\": \"\"\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"scheduled_id\": 0,\n      \"sub_type\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\"\n    },\n    \"PaymentBatch\": {}\n  },\n  \"scheduled_object\": {\n    \"Payment\": {},\n    \"PaymentBatch\": {}\n  },\n  \"state\": \"\",\n  \"time_end\": \"\",\n  \"time_start\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"error_message\": [],\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"result_object\": {\n    \"Payment\": {\n      \"address_billing\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"address_shipping\": {},\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"balance_after_mutation\": {},\n      \"batch_id\": 0,\n      \"bunqto_expiry\": \"\",\n      \"bunqto_share_url\": \"\",\n      \"bunqto_status\": \"\",\n      \"bunqto_sub_status\": \"\",\n      \"bunqto_time_responded\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"geolocation\": {\n        \"altitude\": 0,\n        \"latitude\": 0,\n        \"longitude\": 0,\n        \"radius\": 0\n      },\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"monetary_account_id\": 0,\n      \"payment_auto_allocate_instance\": {\n        \"created\": \"\",\n        \"error_message\": [],\n        \"id\": 0,\n        \"payment_auto_allocate_id\": 0,\n        \"payment_batch\": {\n          \"payments\": {\n            \"Payment\": []\n          }\n        },\n        \"payment_id\": 0,\n        \"status\": \"\",\n        \"updated\": \"\"\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"scheduled_id\": 0,\n      \"sub_type\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\"\n    },\n    \"PaymentBatch\": {}\n  },\n  \"scheduled_object\": {\n    \"Payment\": {},\n    \"PaymentBatch\": {}\n  },\n  \"state\": \"\",\n  \"time_end\": \"\",\n  \"time_start\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"error_message\": [],\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"result_object\": {\n    \"Payment\": {\n      \"address_billing\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"address_shipping\": {},\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"balance_after_mutation\": {},\n      \"batch_id\": 0,\n      \"bunqto_expiry\": \"\",\n      \"bunqto_share_url\": \"\",\n      \"bunqto_status\": \"\",\n      \"bunqto_sub_status\": \"\",\n      \"bunqto_time_responded\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"geolocation\": {\n        \"altitude\": 0,\n        \"latitude\": 0,\n        \"longitude\": 0,\n        \"radius\": 0\n      },\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"monetary_account_id\": 0,\n      \"payment_auto_allocate_instance\": {\n        \"created\": \"\",\n        \"error_message\": [],\n        \"id\": 0,\n        \"payment_auto_allocate_id\": 0,\n        \"payment_batch\": {\n          \"payments\": {\n            \"Payment\": []\n          }\n        },\n        \"payment_id\": 0,\n        \"status\": \"\",\n        \"updated\": \"\"\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"scheduled_id\": 0,\n      \"sub_type\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\"\n    },\n    \"PaymentBatch\": {}\n  },\n  \"scheduled_object\": {\n    \"Payment\": {},\n    \"PaymentBatch\": {}\n  },\n  \"state\": \"\",\n  \"time_end\": \"\",\n  \"time_start\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"error_message\": [],\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"result_object\": {\n    \"Payment\": {\n      \"address_billing\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"address_shipping\": {},\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"balance_after_mutation\": {},\n      \"batch_id\": 0,\n      \"bunqto_expiry\": \"\",\n      \"bunqto_share_url\": \"\",\n      \"bunqto_status\": \"\",\n      \"bunqto_sub_status\": \"\",\n      \"bunqto_time_responded\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"geolocation\": {\n        \"altitude\": 0,\n        \"latitude\": 0,\n        \"longitude\": 0,\n        \"radius\": 0\n      },\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"monetary_account_id\": 0,\n      \"payment_auto_allocate_instance\": {\n        \"created\": \"\",\n        \"error_message\": [],\n        \"id\": 0,\n        \"payment_auto_allocate_id\": 0,\n        \"payment_batch\": {\n          \"payments\": {\n            \"Payment\": []\n          }\n        },\n        \"payment_id\": 0,\n        \"status\": \"\",\n        \"updated\": \"\"\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"scheduled_id\": 0,\n      \"sub_type\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\"\n    },\n    \"PaymentBatch\": {}\n  },\n  \"scheduled_object\": {\n    \"Payment\": {},\n    \"PaymentBatch\": {}\n  },\n  \"state\": \"\",\n  \"time_end\": \"\",\n  \"time_start\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  error_message: [],
  request_reference_split_the_bill: [
    {
      id: 0,
      type: ''
    }
  ],
  result_object: {
    Payment: {
      address_billing: {
        city: '',
        country: '',
        extra: '',
        house_number: '',
        is_user_address_updated: false,
        mailbox_name: '',
        po_box: '',
        postal_code: '',
        province: '',
        street: ''
      },
      address_shipping: {},
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [
            {
              attachment_public_uuid: '',
              content_type: '',
              height: 0,
              width: 0
            }
          ],
          style: '',
          uuid: ''
        },
        bunq_me: {
          name: '',
          service: '',
          type: '',
          value: ''
        },
        country: '',
        display_name: '',
        iban: '',
        is_light: false,
        label_user: {
          avatar: {},
          country: '',
          display_name: '',
          public_nick_name: '',
          uuid: ''
        },
        merchant_category_code: '',
        swift_account_number: '',
        swift_bic: '',
        transferwise_account_number: '',
        transferwise_bank_code: ''
      },
      allow_bunqto: false,
      amount: {
        currency: '',
        value: ''
      },
      attachment: [
        {
          id: 0,
          monetary_account_id: 0
        }
      ],
      balance_after_mutation: {},
      batch_id: 0,
      bunqto_expiry: '',
      bunqto_share_url: '',
      bunqto_status: '',
      bunqto_sub_status: '',
      bunqto_time_responded: '',
      counterparty_alias: {},
      created: '',
      description: '',
      geolocation: {
        altitude: 0,
        latitude: 0,
        longitude: 0,
        radius: 0
      },
      id: 0,
      merchant_reference: '',
      monetary_account_id: 0,
      payment_auto_allocate_instance: {
        created: '',
        error_message: [],
        id: 0,
        payment_auto_allocate_id: 0,
        payment_batch: {
          payments: {
            Payment: []
          }
        },
        payment_id: 0,
        status: '',
        updated: ''
      },
      request_reference_split_the_bill: [
        {}
      ],
      scheduled_id: 0,
      sub_type: '',
      type: '',
      updated: ''
    },
    PaymentBatch: {}
  },
  scheduled_object: {
    Payment: {},
    PaymentBatch: {}
  },
  state: '',
  time_end: '',
  time_start: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    error_message: [],
    request_reference_split_the_bill: [{id: 0, type: ''}],
    result_object: {
      Payment: {
        address_billing: {
          city: '',
          country: '',
          extra: '',
          house_number: '',
          is_user_address_updated: false,
          mailbox_name: '',
          po_box: '',
          postal_code: '',
          province: '',
          street: ''
        },
        address_shipping: {},
        alias: {
          avatar: {
            anchor_uuid: '',
            image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
            style: '',
            uuid: ''
          },
          bunq_me: {name: '', service: '', type: '', value: ''},
          country: '',
          display_name: '',
          iban: '',
          is_light: false,
          label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
          merchant_category_code: '',
          swift_account_number: '',
          swift_bic: '',
          transferwise_account_number: '',
          transferwise_bank_code: ''
        },
        allow_bunqto: false,
        amount: {currency: '', value: ''},
        attachment: [{id: 0, monetary_account_id: 0}],
        balance_after_mutation: {},
        batch_id: 0,
        bunqto_expiry: '',
        bunqto_share_url: '',
        bunqto_status: '',
        bunqto_sub_status: '',
        bunqto_time_responded: '',
        counterparty_alias: {},
        created: '',
        description: '',
        geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
        id: 0,
        merchant_reference: '',
        monetary_account_id: 0,
        payment_auto_allocate_instance: {
          created: '',
          error_message: [],
          id: 0,
          payment_auto_allocate_id: 0,
          payment_batch: {payments: {Payment: []}},
          payment_id: 0,
          status: '',
          updated: ''
        },
        request_reference_split_the_bill: [{}],
        scheduled_id: 0,
        sub_type: '',
        type: '',
        updated: ''
      },
      PaymentBatch: {}
    },
    scheduled_object: {Payment: {}, PaymentBatch: {}},
    state: '',
    time_end: '',
    time_start: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"error_message":[],"request_reference_split_the_bill":[{"id":0,"type":""}],"result_object":{"Payment":{"address_billing":{"city":"","country":"","extra":"","house_number":"","is_user_address_updated":false,"mailbox_name":"","po_box":"","postal_code":"","province":"","street":""},"address_shipping":{},"alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"allow_bunqto":false,"amount":{"currency":"","value":""},"attachment":[{"id":0,"monetary_account_id":0}],"balance_after_mutation":{},"batch_id":0,"bunqto_expiry":"","bunqto_share_url":"","bunqto_status":"","bunqto_sub_status":"","bunqto_time_responded":"","counterparty_alias":{},"created":"","description":"","geolocation":{"altitude":0,"latitude":0,"longitude":0,"radius":0},"id":0,"merchant_reference":"","monetary_account_id":0,"payment_auto_allocate_instance":{"created":"","error_message":[],"id":0,"payment_auto_allocate_id":0,"payment_batch":{"payments":{"Payment":[]}},"payment_id":0,"status":"","updated":""},"request_reference_split_the_bill":[{}],"scheduled_id":0,"sub_type":"","type":"","updated":""},"PaymentBatch":{}},"scheduled_object":{"Payment":{},"PaymentBatch":{}},"state":"","time_end":"","time_start":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "error_message": [],\n  "request_reference_split_the_bill": [\n    {\n      "id": 0,\n      "type": ""\n    }\n  ],\n  "result_object": {\n    "Payment": {\n      "address_billing": {\n        "city": "",\n        "country": "",\n        "extra": "",\n        "house_number": "",\n        "is_user_address_updated": false,\n        "mailbox_name": "",\n        "po_box": "",\n        "postal_code": "",\n        "province": "",\n        "street": ""\n      },\n      "address_shipping": {},\n      "alias": {\n        "avatar": {\n          "anchor_uuid": "",\n          "image": [\n            {\n              "attachment_public_uuid": "",\n              "content_type": "",\n              "height": 0,\n              "width": 0\n            }\n          ],\n          "style": "",\n          "uuid": ""\n        },\n        "bunq_me": {\n          "name": "",\n          "service": "",\n          "type": "",\n          "value": ""\n        },\n        "country": "",\n        "display_name": "",\n        "iban": "",\n        "is_light": false,\n        "label_user": {\n          "avatar": {},\n          "country": "",\n          "display_name": "",\n          "public_nick_name": "",\n          "uuid": ""\n        },\n        "merchant_category_code": "",\n        "swift_account_number": "",\n        "swift_bic": "",\n        "transferwise_account_number": "",\n        "transferwise_bank_code": ""\n      },\n      "allow_bunqto": false,\n      "amount": {\n        "currency": "",\n        "value": ""\n      },\n      "attachment": [\n        {\n          "id": 0,\n          "monetary_account_id": 0\n        }\n      ],\n      "balance_after_mutation": {},\n      "batch_id": 0,\n      "bunqto_expiry": "",\n      "bunqto_share_url": "",\n      "bunqto_status": "",\n      "bunqto_sub_status": "",\n      "bunqto_time_responded": "",\n      "counterparty_alias": {},\n      "created": "",\n      "description": "",\n      "geolocation": {\n        "altitude": 0,\n        "latitude": 0,\n        "longitude": 0,\n        "radius": 0\n      },\n      "id": 0,\n      "merchant_reference": "",\n      "monetary_account_id": 0,\n      "payment_auto_allocate_instance": {\n        "created": "",\n        "error_message": [],\n        "id": 0,\n        "payment_auto_allocate_id": 0,\n        "payment_batch": {\n          "payments": {\n            "Payment": []\n          }\n        },\n        "payment_id": 0,\n        "status": "",\n        "updated": ""\n      },\n      "request_reference_split_the_bill": [\n        {}\n      ],\n      "scheduled_id": 0,\n      "sub_type": "",\n      "type": "",\n      "updated": ""\n    },\n    "PaymentBatch": {}\n  },\n  "scheduled_object": {\n    "Payment": {},\n    "PaymentBatch": {}\n  },\n  "state": "",\n  "time_end": "",\n  "time_start": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"error_message\": [],\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"result_object\": {\n    \"Payment\": {\n      \"address_billing\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"address_shipping\": {},\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"balance_after_mutation\": {},\n      \"batch_id\": 0,\n      \"bunqto_expiry\": \"\",\n      \"bunqto_share_url\": \"\",\n      \"bunqto_status\": \"\",\n      \"bunqto_sub_status\": \"\",\n      \"bunqto_time_responded\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"geolocation\": {\n        \"altitude\": 0,\n        \"latitude\": 0,\n        \"longitude\": 0,\n        \"radius\": 0\n      },\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"monetary_account_id\": 0,\n      \"payment_auto_allocate_instance\": {\n        \"created\": \"\",\n        \"error_message\": [],\n        \"id\": 0,\n        \"payment_auto_allocate_id\": 0,\n        \"payment_batch\": {\n          \"payments\": {\n            \"Payment\": []\n          }\n        },\n        \"payment_id\": 0,\n        \"status\": \"\",\n        \"updated\": \"\"\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"scheduled_id\": 0,\n      \"sub_type\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\"\n    },\n    \"PaymentBatch\": {}\n  },\n  \"scheduled_object\": {\n    \"Payment\": {},\n    \"PaymentBatch\": {}\n  },\n  \"state\": \"\",\n  \"time_end\": \"\",\n  \"time_start\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  error_message: [],
  request_reference_split_the_bill: [{id: 0, type: ''}],
  result_object: {
    Payment: {
      address_billing: {
        city: '',
        country: '',
        extra: '',
        house_number: '',
        is_user_address_updated: false,
        mailbox_name: '',
        po_box: '',
        postal_code: '',
        province: '',
        street: ''
      },
      address_shipping: {},
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
          style: '',
          uuid: ''
        },
        bunq_me: {name: '', service: '', type: '', value: ''},
        country: '',
        display_name: '',
        iban: '',
        is_light: false,
        label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
        merchant_category_code: '',
        swift_account_number: '',
        swift_bic: '',
        transferwise_account_number: '',
        transferwise_bank_code: ''
      },
      allow_bunqto: false,
      amount: {currency: '', value: ''},
      attachment: [{id: 0, monetary_account_id: 0}],
      balance_after_mutation: {},
      batch_id: 0,
      bunqto_expiry: '',
      bunqto_share_url: '',
      bunqto_status: '',
      bunqto_sub_status: '',
      bunqto_time_responded: '',
      counterparty_alias: {},
      created: '',
      description: '',
      geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
      id: 0,
      merchant_reference: '',
      monetary_account_id: 0,
      payment_auto_allocate_instance: {
        created: '',
        error_message: [],
        id: 0,
        payment_auto_allocate_id: 0,
        payment_batch: {payments: {Payment: []}},
        payment_id: 0,
        status: '',
        updated: ''
      },
      request_reference_split_the_bill: [{}],
      scheduled_id: 0,
      sub_type: '',
      type: '',
      updated: ''
    },
    PaymentBatch: {}
  },
  scheduled_object: {Payment: {}, PaymentBatch: {}},
  state: '',
  time_end: '',
  time_start: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    error_message: [],
    request_reference_split_the_bill: [{id: 0, type: ''}],
    result_object: {
      Payment: {
        address_billing: {
          city: '',
          country: '',
          extra: '',
          house_number: '',
          is_user_address_updated: false,
          mailbox_name: '',
          po_box: '',
          postal_code: '',
          province: '',
          street: ''
        },
        address_shipping: {},
        alias: {
          avatar: {
            anchor_uuid: '',
            image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
            style: '',
            uuid: ''
          },
          bunq_me: {name: '', service: '', type: '', value: ''},
          country: '',
          display_name: '',
          iban: '',
          is_light: false,
          label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
          merchant_category_code: '',
          swift_account_number: '',
          swift_bic: '',
          transferwise_account_number: '',
          transferwise_bank_code: ''
        },
        allow_bunqto: false,
        amount: {currency: '', value: ''},
        attachment: [{id: 0, monetary_account_id: 0}],
        balance_after_mutation: {},
        batch_id: 0,
        bunqto_expiry: '',
        bunqto_share_url: '',
        bunqto_status: '',
        bunqto_sub_status: '',
        bunqto_time_responded: '',
        counterparty_alias: {},
        created: '',
        description: '',
        geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
        id: 0,
        merchant_reference: '',
        monetary_account_id: 0,
        payment_auto_allocate_instance: {
          created: '',
          error_message: [],
          id: 0,
          payment_auto_allocate_id: 0,
          payment_batch: {payments: {Payment: []}},
          payment_id: 0,
          status: '',
          updated: ''
        },
        request_reference_split_the_bill: [{}],
        scheduled_id: 0,
        sub_type: '',
        type: '',
        updated: ''
      },
      PaymentBatch: {}
    },
    scheduled_object: {Payment: {}, PaymentBatch: {}},
    state: '',
    time_end: '',
    time_start: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  error_message: [],
  request_reference_split_the_bill: [
    {
      id: 0,
      type: ''
    }
  ],
  result_object: {
    Payment: {
      address_billing: {
        city: '',
        country: '',
        extra: '',
        house_number: '',
        is_user_address_updated: false,
        mailbox_name: '',
        po_box: '',
        postal_code: '',
        province: '',
        street: ''
      },
      address_shipping: {},
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [
            {
              attachment_public_uuid: '',
              content_type: '',
              height: 0,
              width: 0
            }
          ],
          style: '',
          uuid: ''
        },
        bunq_me: {
          name: '',
          service: '',
          type: '',
          value: ''
        },
        country: '',
        display_name: '',
        iban: '',
        is_light: false,
        label_user: {
          avatar: {},
          country: '',
          display_name: '',
          public_nick_name: '',
          uuid: ''
        },
        merchant_category_code: '',
        swift_account_number: '',
        swift_bic: '',
        transferwise_account_number: '',
        transferwise_bank_code: ''
      },
      allow_bunqto: false,
      amount: {
        currency: '',
        value: ''
      },
      attachment: [
        {
          id: 0,
          monetary_account_id: 0
        }
      ],
      balance_after_mutation: {},
      batch_id: 0,
      bunqto_expiry: '',
      bunqto_share_url: '',
      bunqto_status: '',
      bunqto_sub_status: '',
      bunqto_time_responded: '',
      counterparty_alias: {},
      created: '',
      description: '',
      geolocation: {
        altitude: 0,
        latitude: 0,
        longitude: 0,
        radius: 0
      },
      id: 0,
      merchant_reference: '',
      monetary_account_id: 0,
      payment_auto_allocate_instance: {
        created: '',
        error_message: [],
        id: 0,
        payment_auto_allocate_id: 0,
        payment_batch: {
          payments: {
            Payment: []
          }
        },
        payment_id: 0,
        status: '',
        updated: ''
      },
      request_reference_split_the_bill: [
        {}
      ],
      scheduled_id: 0,
      sub_type: '',
      type: '',
      updated: ''
    },
    PaymentBatch: {}
  },
  scheduled_object: {
    Payment: {},
    PaymentBatch: {}
  },
  state: '',
  time_end: '',
  time_start: ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    error_message: [],
    request_reference_split_the_bill: [{id: 0, type: ''}],
    result_object: {
      Payment: {
        address_billing: {
          city: '',
          country: '',
          extra: '',
          house_number: '',
          is_user_address_updated: false,
          mailbox_name: '',
          po_box: '',
          postal_code: '',
          province: '',
          street: ''
        },
        address_shipping: {},
        alias: {
          avatar: {
            anchor_uuid: '',
            image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
            style: '',
            uuid: ''
          },
          bunq_me: {name: '', service: '', type: '', value: ''},
          country: '',
          display_name: '',
          iban: '',
          is_light: false,
          label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
          merchant_category_code: '',
          swift_account_number: '',
          swift_bic: '',
          transferwise_account_number: '',
          transferwise_bank_code: ''
        },
        allow_bunqto: false,
        amount: {currency: '', value: ''},
        attachment: [{id: 0, monetary_account_id: 0}],
        balance_after_mutation: {},
        batch_id: 0,
        bunqto_expiry: '',
        bunqto_share_url: '',
        bunqto_status: '',
        bunqto_sub_status: '',
        bunqto_time_responded: '',
        counterparty_alias: {},
        created: '',
        description: '',
        geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
        id: 0,
        merchant_reference: '',
        monetary_account_id: 0,
        payment_auto_allocate_instance: {
          created: '',
          error_message: [],
          id: 0,
          payment_auto_allocate_id: 0,
          payment_batch: {payments: {Payment: []}},
          payment_id: 0,
          status: '',
          updated: ''
        },
        request_reference_split_the_bill: [{}],
        scheduled_id: 0,
        sub_type: '',
        type: '',
        updated: ''
      },
      PaymentBatch: {}
    },
    scheduled_object: {Payment: {}, PaymentBatch: {}},
    state: '',
    time_end: '',
    time_start: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"error_message":[],"request_reference_split_the_bill":[{"id":0,"type":""}],"result_object":{"Payment":{"address_billing":{"city":"","country":"","extra":"","house_number":"","is_user_address_updated":false,"mailbox_name":"","po_box":"","postal_code":"","province":"","street":""},"address_shipping":{},"alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"allow_bunqto":false,"amount":{"currency":"","value":""},"attachment":[{"id":0,"monetary_account_id":0}],"balance_after_mutation":{},"batch_id":0,"bunqto_expiry":"","bunqto_share_url":"","bunqto_status":"","bunqto_sub_status":"","bunqto_time_responded":"","counterparty_alias":{},"created":"","description":"","geolocation":{"altitude":0,"latitude":0,"longitude":0,"radius":0},"id":0,"merchant_reference":"","monetary_account_id":0,"payment_auto_allocate_instance":{"created":"","error_message":[],"id":0,"payment_auto_allocate_id":0,"payment_batch":{"payments":{"Payment":[]}},"payment_id":0,"status":"","updated":""},"request_reference_split_the_bill":[{}],"scheduled_id":0,"sub_type":"","type":"","updated":""},"PaymentBatch":{}},"scheduled_object":{"Payment":{},"PaymentBatch":{}},"state":"","time_end":"","time_start":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"error_message": @[  ],
                              @"request_reference_split_the_bill": @[ @{ @"id": @0, @"type": @"" } ],
                              @"result_object": @{ @"Payment": @{ @"address_billing": @{ @"city": @"", @"country": @"", @"extra": @"", @"house_number": @"", @"is_user_address_updated": @NO, @"mailbox_name": @"", @"po_box": @"", @"postal_code": @"", @"province": @"", @"street": @"" }, @"address_shipping": @{  }, @"alias": @{ @"avatar": @{ @"anchor_uuid": @"", @"image": @[ @{ @"attachment_public_uuid": @"", @"content_type": @"", @"height": @0, @"width": @0 } ], @"style": @"", @"uuid": @"" }, @"bunq_me": @{ @"name": @"", @"service": @"", @"type": @"", @"value": @"" }, @"country": @"", @"display_name": @"", @"iban": @"", @"is_light": @NO, @"label_user": @{ @"avatar": @{  }, @"country": @"", @"display_name": @"", @"public_nick_name": @"", @"uuid": @"" }, @"merchant_category_code": @"", @"swift_account_number": @"", @"swift_bic": @"", @"transferwise_account_number": @"", @"transferwise_bank_code": @"" }, @"allow_bunqto": @NO, @"amount": @{ @"currency": @"", @"value": @"" }, @"attachment": @[ @{ @"id": @0, @"monetary_account_id": @0 } ], @"balance_after_mutation": @{  }, @"batch_id": @0, @"bunqto_expiry": @"", @"bunqto_share_url": @"", @"bunqto_status": @"", @"bunqto_sub_status": @"", @"bunqto_time_responded": @"", @"counterparty_alias": @{  }, @"created": @"", @"description": @"", @"geolocation": @{ @"altitude": @0, @"latitude": @0, @"longitude": @0, @"radius": @0 }, @"id": @0, @"merchant_reference": @"", @"monetary_account_id": @0, @"payment_auto_allocate_instance": @{ @"created": @"", @"error_message": @[  ], @"id": @0, @"payment_auto_allocate_id": @0, @"payment_batch": @{ @"payments": @{ @"Payment": @[  ] } }, @"payment_id": @0, @"status": @"", @"updated": @"" }, @"request_reference_split_the_bill": @[ @{  } ], @"scheduled_id": @0, @"sub_type": @"", @"type": @"", @"updated": @"" }, @"PaymentBatch": @{  } },
                              @"scheduled_object": @{ @"Payment": @{  }, @"PaymentBatch": @{  } },
                              @"state": @"",
                              @"time_end": @"",
                              @"time_start": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"error_message\": [],\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"result_object\": {\n    \"Payment\": {\n      \"address_billing\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"address_shipping\": {},\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"balance_after_mutation\": {},\n      \"batch_id\": 0,\n      \"bunqto_expiry\": \"\",\n      \"bunqto_share_url\": \"\",\n      \"bunqto_status\": \"\",\n      \"bunqto_sub_status\": \"\",\n      \"bunqto_time_responded\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"geolocation\": {\n        \"altitude\": 0,\n        \"latitude\": 0,\n        \"longitude\": 0,\n        \"radius\": 0\n      },\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"monetary_account_id\": 0,\n      \"payment_auto_allocate_instance\": {\n        \"created\": \"\",\n        \"error_message\": [],\n        \"id\": 0,\n        \"payment_auto_allocate_id\": 0,\n        \"payment_batch\": {\n          \"payments\": {\n            \"Payment\": []\n          }\n        },\n        \"payment_id\": 0,\n        \"status\": \"\",\n        \"updated\": \"\"\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"scheduled_id\": 0,\n      \"sub_type\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\"\n    },\n    \"PaymentBatch\": {}\n  },\n  \"scheduled_object\": {\n    \"Payment\": {},\n    \"PaymentBatch\": {}\n  },\n  \"state\": \"\",\n  \"time_end\": \"\",\n  \"time_start\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'error_message' => [
        
    ],
    'request_reference_split_the_bill' => [
        [
                'id' => 0,
                'type' => ''
        ]
    ],
    'result_object' => [
        'Payment' => [
                'address_billing' => [
                                'city' => '',
                                'country' => '',
                                'extra' => '',
                                'house_number' => '',
                                'is_user_address_updated' => null,
                                'mailbox_name' => '',
                                'po_box' => '',
                                'postal_code' => '',
                                'province' => '',
                                'street' => ''
                ],
                'address_shipping' => [
                                
                ],
                'alias' => [
                                'avatar' => [
                                                                'anchor_uuid' => '',
                                                                'image' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'attachment_public_uuid' => '',
                                                                                                                                                                                                                                                                'content_type' => '',
                                                                                                                                                                                                                                                                'height' => 0,
                                                                                                                                                                                                                                                                'width' => 0
                                                                                                                                ]
                                                                ],
                                                                'style' => '',
                                                                'uuid' => ''
                                ],
                                'bunq_me' => [
                                                                'name' => '',
                                                                'service' => '',
                                                                'type' => '',
                                                                'value' => ''
                                ],
                                'country' => '',
                                'display_name' => '',
                                'iban' => '',
                                'is_light' => null,
                                'label_user' => [
                                                                'avatar' => [
                                                                                                                                
                                                                ],
                                                                'country' => '',
                                                                'display_name' => '',
                                                                'public_nick_name' => '',
                                                                'uuid' => ''
                                ],
                                'merchant_category_code' => '',
                                'swift_account_number' => '',
                                'swift_bic' => '',
                                'transferwise_account_number' => '',
                                'transferwise_bank_code' => ''
                ],
                'allow_bunqto' => null,
                'amount' => [
                                'currency' => '',
                                'value' => ''
                ],
                'attachment' => [
                                [
                                                                'id' => 0,
                                                                'monetary_account_id' => 0
                                ]
                ],
                'balance_after_mutation' => [
                                
                ],
                'batch_id' => 0,
                'bunqto_expiry' => '',
                'bunqto_share_url' => '',
                'bunqto_status' => '',
                'bunqto_sub_status' => '',
                'bunqto_time_responded' => '',
                'counterparty_alias' => [
                                
                ],
                'created' => '',
                'description' => '',
                'geolocation' => [
                                'altitude' => 0,
                                'latitude' => 0,
                                'longitude' => 0,
                                'radius' => 0
                ],
                'id' => 0,
                'merchant_reference' => '',
                'monetary_account_id' => 0,
                'payment_auto_allocate_instance' => [
                                'created' => '',
                                'error_message' => [
                                                                
                                ],
                                'id' => 0,
                                'payment_auto_allocate_id' => 0,
                                'payment_batch' => [
                                                                'payments' => [
                                                                                                                                'Payment' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'payment_id' => 0,
                                'status' => '',
                                'updated' => ''
                ],
                'request_reference_split_the_bill' => [
                                [
                                                                
                                ]
                ],
                'scheduled_id' => 0,
                'sub_type' => '',
                'type' => '',
                'updated' => ''
        ],
        'PaymentBatch' => [
                
        ]
    ],
    'scheduled_object' => [
        'Payment' => [
                
        ],
        'PaymentBatch' => [
                
        ]
    ],
    'state' => '',
    'time_end' => '',
    'time_start' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId', [
  'body' => '{
  "error_message": [],
  "request_reference_split_the_bill": [
    {
      "id": 0,
      "type": ""
    }
  ],
  "result_object": {
    "Payment": {
      "address_billing": {
        "city": "",
        "country": "",
        "extra": "",
        "house_number": "",
        "is_user_address_updated": false,
        "mailbox_name": "",
        "po_box": "",
        "postal_code": "",
        "province": "",
        "street": ""
      },
      "address_shipping": {},
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "allow_bunqto": false,
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "balance_after_mutation": {},
      "batch_id": 0,
      "bunqto_expiry": "",
      "bunqto_share_url": "",
      "bunqto_status": "",
      "bunqto_sub_status": "",
      "bunqto_time_responded": "",
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "geolocation": {
        "altitude": 0,
        "latitude": 0,
        "longitude": 0,
        "radius": 0
      },
      "id": 0,
      "merchant_reference": "",
      "monetary_account_id": 0,
      "payment_auto_allocate_instance": {
        "created": "",
        "error_message": [],
        "id": 0,
        "payment_auto_allocate_id": 0,
        "payment_batch": {
          "payments": {
            "Payment": []
          }
        },
        "payment_id": 0,
        "status": "",
        "updated": ""
      },
      "request_reference_split_the_bill": [
        {}
      ],
      "scheduled_id": 0,
      "sub_type": "",
      "type": "",
      "updated": ""
    },
    "PaymentBatch": {}
  },
  "scheduled_object": {
    "Payment": {},
    "PaymentBatch": {}
  },
  "state": "",
  "time_end": "",
  "time_start": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'error_message' => [
    
  ],
  'request_reference_split_the_bill' => [
    [
        'id' => 0,
        'type' => ''
    ]
  ],
  'result_object' => [
    'Payment' => [
        'address_billing' => [
                'city' => '',
                'country' => '',
                'extra' => '',
                'house_number' => '',
                'is_user_address_updated' => null,
                'mailbox_name' => '',
                'po_box' => '',
                'postal_code' => '',
                'province' => '',
                'street' => ''
        ],
        'address_shipping' => [
                
        ],
        'alias' => [
                'avatar' => [
                                'anchor_uuid' => '',
                                'image' => [
                                                                [
                                                                                                                                'attachment_public_uuid' => '',
                                                                                                                                'content_type' => '',
                                                                                                                                'height' => 0,
                                                                                                                                'width' => 0
                                                                ]
                                ],
                                'style' => '',
                                'uuid' => ''
                ],
                'bunq_me' => [
                                'name' => '',
                                'service' => '',
                                'type' => '',
                                'value' => ''
                ],
                'country' => '',
                'display_name' => '',
                'iban' => '',
                'is_light' => null,
                'label_user' => [
                                'avatar' => [
                                                                
                                ],
                                'country' => '',
                                'display_name' => '',
                                'public_nick_name' => '',
                                'uuid' => ''
                ],
                'merchant_category_code' => '',
                'swift_account_number' => '',
                'swift_bic' => '',
                'transferwise_account_number' => '',
                'transferwise_bank_code' => ''
        ],
        'allow_bunqto' => null,
        'amount' => [
                'currency' => '',
                'value' => ''
        ],
        'attachment' => [
                [
                                'id' => 0,
                                'monetary_account_id' => 0
                ]
        ],
        'balance_after_mutation' => [
                
        ],
        'batch_id' => 0,
        'bunqto_expiry' => '',
        'bunqto_share_url' => '',
        'bunqto_status' => '',
        'bunqto_sub_status' => '',
        'bunqto_time_responded' => '',
        'counterparty_alias' => [
                
        ],
        'created' => '',
        'description' => '',
        'geolocation' => [
                'altitude' => 0,
                'latitude' => 0,
                'longitude' => 0,
                'radius' => 0
        ],
        'id' => 0,
        'merchant_reference' => '',
        'monetary_account_id' => 0,
        'payment_auto_allocate_instance' => [
                'created' => '',
                'error_message' => [
                                
                ],
                'id' => 0,
                'payment_auto_allocate_id' => 0,
                'payment_batch' => [
                                'payments' => [
                                                                'Payment' => [
                                                                                                                                
                                                                ]
                                ]
                ],
                'payment_id' => 0,
                'status' => '',
                'updated' => ''
        ],
        'request_reference_split_the_bill' => [
                [
                                
                ]
        ],
        'scheduled_id' => 0,
        'sub_type' => '',
        'type' => '',
        'updated' => ''
    ],
    'PaymentBatch' => [
        
    ]
  ],
  'scheduled_object' => [
    'Payment' => [
        
    ],
    'PaymentBatch' => [
        
    ]
  ],
  'state' => '',
  'time_end' => '',
  'time_start' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'error_message' => [
    
  ],
  'request_reference_split_the_bill' => [
    [
        'id' => 0,
        'type' => ''
    ]
  ],
  'result_object' => [
    'Payment' => [
        'address_billing' => [
                'city' => '',
                'country' => '',
                'extra' => '',
                'house_number' => '',
                'is_user_address_updated' => null,
                'mailbox_name' => '',
                'po_box' => '',
                'postal_code' => '',
                'province' => '',
                'street' => ''
        ],
        'address_shipping' => [
                
        ],
        'alias' => [
                'avatar' => [
                                'anchor_uuid' => '',
                                'image' => [
                                                                [
                                                                                                                                'attachment_public_uuid' => '',
                                                                                                                                'content_type' => '',
                                                                                                                                'height' => 0,
                                                                                                                                'width' => 0
                                                                ]
                                ],
                                'style' => '',
                                'uuid' => ''
                ],
                'bunq_me' => [
                                'name' => '',
                                'service' => '',
                                'type' => '',
                                'value' => ''
                ],
                'country' => '',
                'display_name' => '',
                'iban' => '',
                'is_light' => null,
                'label_user' => [
                                'avatar' => [
                                                                
                                ],
                                'country' => '',
                                'display_name' => '',
                                'public_nick_name' => '',
                                'uuid' => ''
                ],
                'merchant_category_code' => '',
                'swift_account_number' => '',
                'swift_bic' => '',
                'transferwise_account_number' => '',
                'transferwise_bank_code' => ''
        ],
        'allow_bunqto' => null,
        'amount' => [
                'currency' => '',
                'value' => ''
        ],
        'attachment' => [
                [
                                'id' => 0,
                                'monetary_account_id' => 0
                ]
        ],
        'balance_after_mutation' => [
                
        ],
        'batch_id' => 0,
        'bunqto_expiry' => '',
        'bunqto_share_url' => '',
        'bunqto_status' => '',
        'bunqto_sub_status' => '',
        'bunqto_time_responded' => '',
        'counterparty_alias' => [
                
        ],
        'created' => '',
        'description' => '',
        'geolocation' => [
                'altitude' => 0,
                'latitude' => 0,
                'longitude' => 0,
                'radius' => 0
        ],
        'id' => 0,
        'merchant_reference' => '',
        'monetary_account_id' => 0,
        'payment_auto_allocate_instance' => [
                'created' => '',
                'error_message' => [
                                
                ],
                'id' => 0,
                'payment_auto_allocate_id' => 0,
                'payment_batch' => [
                                'payments' => [
                                                                'Payment' => [
                                                                                                                                
                                                                ]
                                ]
                ],
                'payment_id' => 0,
                'status' => '',
                'updated' => ''
        ],
        'request_reference_split_the_bill' => [
                [
                                
                ]
        ],
        'scheduled_id' => 0,
        'sub_type' => '',
        'type' => '',
        'updated' => ''
    ],
    'PaymentBatch' => [
        
    ]
  ],
  'scheduled_object' => [
    'Payment' => [
        
    ],
    'PaymentBatch' => [
        
    ]
  ],
  'state' => '',
  'time_end' => '',
  'time_start' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "error_message": [],
  "request_reference_split_the_bill": [
    {
      "id": 0,
      "type": ""
    }
  ],
  "result_object": {
    "Payment": {
      "address_billing": {
        "city": "",
        "country": "",
        "extra": "",
        "house_number": "",
        "is_user_address_updated": false,
        "mailbox_name": "",
        "po_box": "",
        "postal_code": "",
        "province": "",
        "street": ""
      },
      "address_shipping": {},
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "allow_bunqto": false,
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "balance_after_mutation": {},
      "batch_id": 0,
      "bunqto_expiry": "",
      "bunqto_share_url": "",
      "bunqto_status": "",
      "bunqto_sub_status": "",
      "bunqto_time_responded": "",
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "geolocation": {
        "altitude": 0,
        "latitude": 0,
        "longitude": 0,
        "radius": 0
      },
      "id": 0,
      "merchant_reference": "",
      "monetary_account_id": 0,
      "payment_auto_allocate_instance": {
        "created": "",
        "error_message": [],
        "id": 0,
        "payment_auto_allocate_id": 0,
        "payment_batch": {
          "payments": {
            "Payment": []
          }
        },
        "payment_id": 0,
        "status": "",
        "updated": ""
      },
      "request_reference_split_the_bill": [
        {}
      ],
      "scheduled_id": 0,
      "sub_type": "",
      "type": "",
      "updated": ""
    },
    "PaymentBatch": {}
  },
  "scheduled_object": {
    "Payment": {},
    "PaymentBatch": {}
  },
  "state": "",
  "time_end": "",
  "time_start": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "error_message": [],
  "request_reference_split_the_bill": [
    {
      "id": 0,
      "type": ""
    }
  ],
  "result_object": {
    "Payment": {
      "address_billing": {
        "city": "",
        "country": "",
        "extra": "",
        "house_number": "",
        "is_user_address_updated": false,
        "mailbox_name": "",
        "po_box": "",
        "postal_code": "",
        "province": "",
        "street": ""
      },
      "address_shipping": {},
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "allow_bunqto": false,
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "balance_after_mutation": {},
      "batch_id": 0,
      "bunqto_expiry": "",
      "bunqto_share_url": "",
      "bunqto_status": "",
      "bunqto_sub_status": "",
      "bunqto_time_responded": "",
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "geolocation": {
        "altitude": 0,
        "latitude": 0,
        "longitude": 0,
        "radius": 0
      },
      "id": 0,
      "merchant_reference": "",
      "monetary_account_id": 0,
      "payment_auto_allocate_instance": {
        "created": "",
        "error_message": [],
        "id": 0,
        "payment_auto_allocate_id": 0,
        "payment_batch": {
          "payments": {
            "Payment": []
          }
        },
        "payment_id": 0,
        "status": "",
        "updated": ""
      },
      "request_reference_split_the_bill": [
        {}
      ],
      "scheduled_id": 0,
      "sub_type": "",
      "type": "",
      "updated": ""
    },
    "PaymentBatch": {}
  },
  "scheduled_object": {
    "Payment": {},
    "PaymentBatch": {}
  },
  "state": "",
  "time_end": "",
  "time_start": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"error_message\": [],\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"result_object\": {\n    \"Payment\": {\n      \"address_billing\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"address_shipping\": {},\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"balance_after_mutation\": {},\n      \"batch_id\": 0,\n      \"bunqto_expiry\": \"\",\n      \"bunqto_share_url\": \"\",\n      \"bunqto_status\": \"\",\n      \"bunqto_sub_status\": \"\",\n      \"bunqto_time_responded\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"geolocation\": {\n        \"altitude\": 0,\n        \"latitude\": 0,\n        \"longitude\": 0,\n        \"radius\": 0\n      },\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"monetary_account_id\": 0,\n      \"payment_auto_allocate_instance\": {\n        \"created\": \"\",\n        \"error_message\": [],\n        \"id\": 0,\n        \"payment_auto_allocate_id\": 0,\n        \"payment_batch\": {\n          \"payments\": {\n            \"Payment\": []\n          }\n        },\n        \"payment_id\": 0,\n        \"status\": \"\",\n        \"updated\": \"\"\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"scheduled_id\": 0,\n      \"sub_type\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\"\n    },\n    \"PaymentBatch\": {}\n  },\n  \"scheduled_object\": {\n    \"Payment\": {},\n    \"PaymentBatch\": {}\n  },\n  \"state\": \"\",\n  \"time_end\": \"\",\n  \"time_start\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId"

payload = {
    "error_message": [],
    "request_reference_split_the_bill": [
        {
            "id": 0,
            "type": ""
        }
    ],
    "result_object": {
        "Payment": {
            "address_billing": {
                "city": "",
                "country": "",
                "extra": "",
                "house_number": "",
                "is_user_address_updated": False,
                "mailbox_name": "",
                "po_box": "",
                "postal_code": "",
                "province": "",
                "street": ""
            },
            "address_shipping": {},
            "alias": {
                "avatar": {
                    "anchor_uuid": "",
                    "image": [
                        {
                            "attachment_public_uuid": "",
                            "content_type": "",
                            "height": 0,
                            "width": 0
                        }
                    ],
                    "style": "",
                    "uuid": ""
                },
                "bunq_me": {
                    "name": "",
                    "service": "",
                    "type": "",
                    "value": ""
                },
                "country": "",
                "display_name": "",
                "iban": "",
                "is_light": False,
                "label_user": {
                    "avatar": {},
                    "country": "",
                    "display_name": "",
                    "public_nick_name": "",
                    "uuid": ""
                },
                "merchant_category_code": "",
                "swift_account_number": "",
                "swift_bic": "",
                "transferwise_account_number": "",
                "transferwise_bank_code": ""
            },
            "allow_bunqto": False,
            "amount": {
                "currency": "",
                "value": ""
            },
            "attachment": [
                {
                    "id": 0,
                    "monetary_account_id": 0
                }
            ],
            "balance_after_mutation": {},
            "batch_id": 0,
            "bunqto_expiry": "",
            "bunqto_share_url": "",
            "bunqto_status": "",
            "bunqto_sub_status": "",
            "bunqto_time_responded": "",
            "counterparty_alias": {},
            "created": "",
            "description": "",
            "geolocation": {
                "altitude": 0,
                "latitude": 0,
                "longitude": 0,
                "radius": 0
            },
            "id": 0,
            "merchant_reference": "",
            "monetary_account_id": 0,
            "payment_auto_allocate_instance": {
                "created": "",
                "error_message": [],
                "id": 0,
                "payment_auto_allocate_id": 0,
                "payment_batch": { "payments": { "Payment": [] } },
                "payment_id": 0,
                "status": "",
                "updated": ""
            },
            "request_reference_split_the_bill": [{}],
            "scheduled_id": 0,
            "sub_type": "",
            "type": "",
            "updated": ""
        },
        "PaymentBatch": {}
    },
    "scheduled_object": {
        "Payment": {},
        "PaymentBatch": {}
    },
    "state": "",
    "time_end": "",
    "time_start": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId"

payload <- "{\n  \"error_message\": [],\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"result_object\": {\n    \"Payment\": {\n      \"address_billing\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"address_shipping\": {},\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"balance_after_mutation\": {},\n      \"batch_id\": 0,\n      \"bunqto_expiry\": \"\",\n      \"bunqto_share_url\": \"\",\n      \"bunqto_status\": \"\",\n      \"bunqto_sub_status\": \"\",\n      \"bunqto_time_responded\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"geolocation\": {\n        \"altitude\": 0,\n        \"latitude\": 0,\n        \"longitude\": 0,\n        \"radius\": 0\n      },\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"monetary_account_id\": 0,\n      \"payment_auto_allocate_instance\": {\n        \"created\": \"\",\n        \"error_message\": [],\n        \"id\": 0,\n        \"payment_auto_allocate_id\": 0,\n        \"payment_batch\": {\n          \"payments\": {\n            \"Payment\": []\n          }\n        },\n        \"payment_id\": 0,\n        \"status\": \"\",\n        \"updated\": \"\"\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"scheduled_id\": 0,\n      \"sub_type\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\"\n    },\n    \"PaymentBatch\": {}\n  },\n  \"scheduled_object\": {\n    \"Payment\": {},\n    \"PaymentBatch\": {}\n  },\n  \"state\": \"\",\n  \"time_end\": \"\",\n  \"time_start\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"error_message\": [],\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"result_object\": {\n    \"Payment\": {\n      \"address_billing\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"address_shipping\": {},\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"balance_after_mutation\": {},\n      \"batch_id\": 0,\n      \"bunqto_expiry\": \"\",\n      \"bunqto_share_url\": \"\",\n      \"bunqto_status\": \"\",\n      \"bunqto_sub_status\": \"\",\n      \"bunqto_time_responded\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"geolocation\": {\n        \"altitude\": 0,\n        \"latitude\": 0,\n        \"longitude\": 0,\n        \"radius\": 0\n      },\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"monetary_account_id\": 0,\n      \"payment_auto_allocate_instance\": {\n        \"created\": \"\",\n        \"error_message\": [],\n        \"id\": 0,\n        \"payment_auto_allocate_id\": 0,\n        \"payment_batch\": {\n          \"payments\": {\n            \"Payment\": []\n          }\n        },\n        \"payment_id\": 0,\n        \"status\": \"\",\n        \"updated\": \"\"\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"scheduled_id\": 0,\n      \"sub_type\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\"\n    },\n    \"PaymentBatch\": {}\n  },\n  \"scheduled_object\": {\n    \"Payment\": {},\n    \"PaymentBatch\": {}\n  },\n  \"state\": \"\",\n  \"time_end\": \"\",\n  \"time_start\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"error_message\": [],\n  \"request_reference_split_the_bill\": [\n    {\n      \"id\": 0,\n      \"type\": \"\"\n    }\n  ],\n  \"result_object\": {\n    \"Payment\": {\n      \"address_billing\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"address_shipping\": {},\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"balance_after_mutation\": {},\n      \"batch_id\": 0,\n      \"bunqto_expiry\": \"\",\n      \"bunqto_share_url\": \"\",\n      \"bunqto_status\": \"\",\n      \"bunqto_sub_status\": \"\",\n      \"bunqto_time_responded\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"geolocation\": {\n        \"altitude\": 0,\n        \"latitude\": 0,\n        \"longitude\": 0,\n        \"radius\": 0\n      },\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"monetary_account_id\": 0,\n      \"payment_auto_allocate_instance\": {\n        \"created\": \"\",\n        \"error_message\": [],\n        \"id\": 0,\n        \"payment_auto_allocate_id\": 0,\n        \"payment_batch\": {\n          \"payments\": {\n            \"Payment\": []\n          }\n        },\n        \"payment_id\": 0,\n        \"status\": \"\",\n        \"updated\": \"\"\n      },\n      \"request_reference_split_the_bill\": [\n        {}\n      ],\n      \"scheduled_id\": 0,\n      \"sub_type\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\"\n    },\n    \"PaymentBatch\": {}\n  },\n  \"scheduled_object\": {\n    \"Payment\": {},\n    \"PaymentBatch\": {}\n  },\n  \"state\": \"\",\n  \"time_end\": \"\",\n  \"time_start\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId";

    let payload = json!({
        "error_message": (),
        "request_reference_split_the_bill": (
            json!({
                "id": 0,
                "type": ""
            })
        ),
        "result_object": json!({
            "Payment": json!({
                "address_billing": json!({
                    "city": "",
                    "country": "",
                    "extra": "",
                    "house_number": "",
                    "is_user_address_updated": false,
                    "mailbox_name": "",
                    "po_box": "",
                    "postal_code": "",
                    "province": "",
                    "street": ""
                }),
                "address_shipping": json!({}),
                "alias": json!({
                    "avatar": json!({
                        "anchor_uuid": "",
                        "image": (
                            json!({
                                "attachment_public_uuid": "",
                                "content_type": "",
                                "height": 0,
                                "width": 0
                            })
                        ),
                        "style": "",
                        "uuid": ""
                    }),
                    "bunq_me": json!({
                        "name": "",
                        "service": "",
                        "type": "",
                        "value": ""
                    }),
                    "country": "",
                    "display_name": "",
                    "iban": "",
                    "is_light": false,
                    "label_user": json!({
                        "avatar": json!({}),
                        "country": "",
                        "display_name": "",
                        "public_nick_name": "",
                        "uuid": ""
                    }),
                    "merchant_category_code": "",
                    "swift_account_number": "",
                    "swift_bic": "",
                    "transferwise_account_number": "",
                    "transferwise_bank_code": ""
                }),
                "allow_bunqto": false,
                "amount": json!({
                    "currency": "",
                    "value": ""
                }),
                "attachment": (
                    json!({
                        "id": 0,
                        "monetary_account_id": 0
                    })
                ),
                "balance_after_mutation": json!({}),
                "batch_id": 0,
                "bunqto_expiry": "",
                "bunqto_share_url": "",
                "bunqto_status": "",
                "bunqto_sub_status": "",
                "bunqto_time_responded": "",
                "counterparty_alias": json!({}),
                "created": "",
                "description": "",
                "geolocation": json!({
                    "altitude": 0,
                    "latitude": 0,
                    "longitude": 0,
                    "radius": 0
                }),
                "id": 0,
                "merchant_reference": "",
                "monetary_account_id": 0,
                "payment_auto_allocate_instance": json!({
                    "created": "",
                    "error_message": (),
                    "id": 0,
                    "payment_auto_allocate_id": 0,
                    "payment_batch": json!({"payments": json!({"Payment": ()})}),
                    "payment_id": 0,
                    "status": "",
                    "updated": ""
                }),
                "request_reference_split_the_bill": (json!({})),
                "scheduled_id": 0,
                "sub_type": "",
                "type": "",
                "updated": ""
            }),
            "PaymentBatch": json!({})
        }),
        "scheduled_object": json!({
            "Payment": json!({}),
            "PaymentBatch": json!({})
        }),
        "state": "",
        "time_end": "",
        "time_start": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "error_message": [],
  "request_reference_split_the_bill": [
    {
      "id": 0,
      "type": ""
    }
  ],
  "result_object": {
    "Payment": {
      "address_billing": {
        "city": "",
        "country": "",
        "extra": "",
        "house_number": "",
        "is_user_address_updated": false,
        "mailbox_name": "",
        "po_box": "",
        "postal_code": "",
        "province": "",
        "street": ""
      },
      "address_shipping": {},
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "allow_bunqto": false,
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "balance_after_mutation": {},
      "batch_id": 0,
      "bunqto_expiry": "",
      "bunqto_share_url": "",
      "bunqto_status": "",
      "bunqto_sub_status": "",
      "bunqto_time_responded": "",
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "geolocation": {
        "altitude": 0,
        "latitude": 0,
        "longitude": 0,
        "radius": 0
      },
      "id": 0,
      "merchant_reference": "",
      "monetary_account_id": 0,
      "payment_auto_allocate_instance": {
        "created": "",
        "error_message": [],
        "id": 0,
        "payment_auto_allocate_id": 0,
        "payment_batch": {
          "payments": {
            "Payment": []
          }
        },
        "payment_id": 0,
        "status": "",
        "updated": ""
      },
      "request_reference_split_the_bill": [
        {}
      ],
      "scheduled_id": 0,
      "sub_type": "",
      "type": "",
      "updated": ""
    },
    "PaymentBatch": {}
  },
  "scheduled_object": {
    "Payment": {},
    "PaymentBatch": {}
  },
  "state": "",
  "time_end": "",
  "time_start": ""
}'
echo '{
  "error_message": [],
  "request_reference_split_the_bill": [
    {
      "id": 0,
      "type": ""
    }
  ],
  "result_object": {
    "Payment": {
      "address_billing": {
        "city": "",
        "country": "",
        "extra": "",
        "house_number": "",
        "is_user_address_updated": false,
        "mailbox_name": "",
        "po_box": "",
        "postal_code": "",
        "province": "",
        "street": ""
      },
      "address_shipping": {},
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "allow_bunqto": false,
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "balance_after_mutation": {},
      "batch_id": 0,
      "bunqto_expiry": "",
      "bunqto_share_url": "",
      "bunqto_status": "",
      "bunqto_sub_status": "",
      "bunqto_time_responded": "",
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "geolocation": {
        "altitude": 0,
        "latitude": 0,
        "longitude": 0,
        "radius": 0
      },
      "id": 0,
      "merchant_reference": "",
      "monetary_account_id": 0,
      "payment_auto_allocate_instance": {
        "created": "",
        "error_message": [],
        "id": 0,
        "payment_auto_allocate_id": 0,
        "payment_batch": {
          "payments": {
            "Payment": []
          }
        },
        "payment_id": 0,
        "status": "",
        "updated": ""
      },
      "request_reference_split_the_bill": [
        {}
      ],
      "scheduled_id": 0,
      "sub_type": "",
      "type": "",
      "updated": ""
    },
    "PaymentBatch": {}
  },
  "scheduled_object": {
    "Payment": {},
    "PaymentBatch": {}
  },
  "state": "",
  "time_end": "",
  "time_start": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "error_message": [],\n  "request_reference_split_the_bill": [\n    {\n      "id": 0,\n      "type": ""\n    }\n  ],\n  "result_object": {\n    "Payment": {\n      "address_billing": {\n        "city": "",\n        "country": "",\n        "extra": "",\n        "house_number": "",\n        "is_user_address_updated": false,\n        "mailbox_name": "",\n        "po_box": "",\n        "postal_code": "",\n        "province": "",\n        "street": ""\n      },\n      "address_shipping": {},\n      "alias": {\n        "avatar": {\n          "anchor_uuid": "",\n          "image": [\n            {\n              "attachment_public_uuid": "",\n              "content_type": "",\n              "height": 0,\n              "width": 0\n            }\n          ],\n          "style": "",\n          "uuid": ""\n        },\n        "bunq_me": {\n          "name": "",\n          "service": "",\n          "type": "",\n          "value": ""\n        },\n        "country": "",\n        "display_name": "",\n        "iban": "",\n        "is_light": false,\n        "label_user": {\n          "avatar": {},\n          "country": "",\n          "display_name": "",\n          "public_nick_name": "",\n          "uuid": ""\n        },\n        "merchant_category_code": "",\n        "swift_account_number": "",\n        "swift_bic": "",\n        "transferwise_account_number": "",\n        "transferwise_bank_code": ""\n      },\n      "allow_bunqto": false,\n      "amount": {\n        "currency": "",\n        "value": ""\n      },\n      "attachment": [\n        {\n          "id": 0,\n          "monetary_account_id": 0\n        }\n      ],\n      "balance_after_mutation": {},\n      "batch_id": 0,\n      "bunqto_expiry": "",\n      "bunqto_share_url": "",\n      "bunqto_status": "",\n      "bunqto_sub_status": "",\n      "bunqto_time_responded": "",\n      "counterparty_alias": {},\n      "created": "",\n      "description": "",\n      "geolocation": {\n        "altitude": 0,\n        "latitude": 0,\n        "longitude": 0,\n        "radius": 0\n      },\n      "id": 0,\n      "merchant_reference": "",\n      "monetary_account_id": 0,\n      "payment_auto_allocate_instance": {\n        "created": "",\n        "error_message": [],\n        "id": 0,\n        "payment_auto_allocate_id": 0,\n        "payment_batch": {\n          "payments": {\n            "Payment": []\n          }\n        },\n        "payment_id": 0,\n        "status": "",\n        "updated": ""\n      },\n      "request_reference_split_the_bill": [\n        {}\n      ],\n      "scheduled_id": 0,\n      "sub_type": "",\n      "type": "",\n      "updated": ""\n    },\n    "PaymentBatch": {}\n  },\n  "scheduled_object": {\n    "Payment": {},\n    "PaymentBatch": {}\n  },\n  "state": "",\n  "time_end": "",\n  "time_start": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "error_message": [],
  "request_reference_split_the_bill": [
    [
      "id": 0,
      "type": ""
    ]
  ],
  "result_object": [
    "Payment": [
      "address_billing": [
        "city": "",
        "country": "",
        "extra": "",
        "house_number": "",
        "is_user_address_updated": false,
        "mailbox_name": "",
        "po_box": "",
        "postal_code": "",
        "province": "",
        "street": ""
      ],
      "address_shipping": [],
      "alias": [
        "avatar": [
          "anchor_uuid": "",
          "image": [
            [
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            ]
          ],
          "style": "",
          "uuid": ""
        ],
        "bunq_me": [
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        ],
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": [
          "avatar": [],
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        ],
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      ],
      "allow_bunqto": false,
      "amount": [
        "currency": "",
        "value": ""
      ],
      "attachment": [
        [
          "id": 0,
          "monetary_account_id": 0
        ]
      ],
      "balance_after_mutation": [],
      "batch_id": 0,
      "bunqto_expiry": "",
      "bunqto_share_url": "",
      "bunqto_status": "",
      "bunqto_sub_status": "",
      "bunqto_time_responded": "",
      "counterparty_alias": [],
      "created": "",
      "description": "",
      "geolocation": [
        "altitude": 0,
        "latitude": 0,
        "longitude": 0,
        "radius": 0
      ],
      "id": 0,
      "merchant_reference": "",
      "monetary_account_id": 0,
      "payment_auto_allocate_instance": [
        "created": "",
        "error_message": [],
        "id": 0,
        "payment_auto_allocate_id": 0,
        "payment_batch": ["payments": ["Payment": []]],
        "payment_id": 0,
        "status": "",
        "updated": ""
      ],
      "request_reference_split_the_bill": [[]],
      "scheduled_id": 0,
      "sub_type": "",
      "type": "",
      "updated": ""
    ],
    "PaymentBatch": []
  ],
  "scheduled_object": [
    "Payment": [],
    "PaymentBatch": []
  ],
  "state": "",
  "time_end": "",
  "time_start": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule/:scheduleID/schedule-instance/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_SchedulePayment_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
BODY json

{
  "payment": {
    "alias": {
      "avatar": {
        "anchor_uuid": "",
        "image": [
          {
            "attachment_public_uuid": "",
            "content_type": "",
            "height": 0,
            "width": 0
          }
        ],
        "style": "",
        "uuid": ""
      },
      "bunq_me": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "country": "",
      "display_name": "",
      "iban": "",
      "is_light": false,
      "label_user": {
        "avatar": {},
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "merchant_category_code": "",
      "swift_account_number": "",
      "swift_bic": "",
      "transferwise_account_number": "",
      "transferwise_bank_code": ""
    },
    "allow_bunqto": false,
    "amount": {
      "currency": "",
      "value": ""
    },
    "attachment": [
      {
        "id": 0,
        "monetary_account_id": 0
      }
    ],
    "counterparty_alias": {},
    "description": "",
    "merchant_reference": ""
  },
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  },
  "status": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"payment\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"allow_bunqto\": false,\n    \"amount\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"attachment\": [\n      {\n        \"id\": 0,\n        \"monetary_account_id\": 0\n      }\n    ],\n    \"counterparty_alias\": {},\n    \"description\": \"\",\n    \"merchant_reference\": \"\"\n  },\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment" {:headers {:user-agent ""
                                                                                                                         :x-bunq-client-authentication ""}
                                                                                                               :content-type :json
                                                                                                               :form-params {:payment {:alias {:avatar {:anchor_uuid ""
                                                                                                                                                        :image [{:attachment_public_uuid ""
                                                                                                                                                                 :content_type ""
                                                                                                                                                                 :height 0
                                                                                                                                                                 :width 0}]
                                                                                                                                                        :style ""
                                                                                                                                                        :uuid ""}
                                                                                                                                               :bunq_me {:name ""
                                                                                                                                                         :service ""
                                                                                                                                                         :type ""
                                                                                                                                                         :value ""}
                                                                                                                                               :country ""
                                                                                                                                               :display_name ""
                                                                                                                                               :iban ""
                                                                                                                                               :is_light false
                                                                                                                                               :label_user {:avatar {}
                                                                                                                                                            :country ""
                                                                                                                                                            :display_name ""
                                                                                                                                                            :public_nick_name ""
                                                                                                                                                            :uuid ""}
                                                                                                                                               :merchant_category_code ""
                                                                                                                                               :swift_account_number ""
                                                                                                                                               :swift_bic ""
                                                                                                                                               :transferwise_account_number ""
                                                                                                                                               :transferwise_bank_code ""}
                                                                                                                                       :allow_bunqto false
                                                                                                                                       :amount {:currency ""
                                                                                                                                                :value ""}
                                                                                                                                       :attachment [{:id 0
                                                                                                                                                     :monetary_account_id 0}]
                                                                                                                                       :counterparty_alias {}
                                                                                                                                       :description ""
                                                                                                                                       :merchant_reference ""}
                                                                                                                             :schedule {:object {:Payment {:address_billing {:city ""
                                                                                                                                                                             :country ""
                                                                                                                                                                             :extra ""
                                                                                                                                                                             :house_number ""
                                                                                                                                                                             :is_user_address_updated false
                                                                                                                                                                             :mailbox_name ""
                                                                                                                                                                             :po_box ""
                                                                                                                                                                             :postal_code ""
                                                                                                                                                                             :province ""
                                                                                                                                                                             :street ""}
                                                                                                                                                           :address_shipping {}
                                                                                                                                                           :alias {}
                                                                                                                                                           :allow_bunqto false
                                                                                                                                                           :amount {}
                                                                                                                                                           :attachment [{}]
                                                                                                                                                           :balance_after_mutation {}
                                                                                                                                                           :batch_id 0
                                                                                                                                                           :bunqto_expiry ""
                                                                                                                                                           :bunqto_share_url ""
                                                                                                                                                           :bunqto_status ""
                                                                                                                                                           :bunqto_sub_status ""
                                                                                                                                                           :bunqto_time_responded ""
                                                                                                                                                           :counterparty_alias {}
                                                                                                                                                           :created ""
                                                                                                                                                           :description ""
                                                                                                                                                           :geolocation {:altitude 0
                                                                                                                                                                         :latitude 0
                                                                                                                                                                         :longitude 0
                                                                                                                                                                         :radius 0}
                                                                                                                                                           :id 0
                                                                                                                                                           :merchant_reference ""
                                                                                                                                                           :monetary_account_id 0
                                                                                                                                                           :payment_auto_allocate_instance {:created ""
                                                                                                                                                                                            :error_message []
                                                                                                                                                                                            :id 0
                                                                                                                                                                                            :payment_auto_allocate_id 0
                                                                                                                                                                                            :payment_batch {:payments {:Payment []}}
                                                                                                                                                                                            :payment_id 0
                                                                                                                                                                                            :status ""
                                                                                                                                                                                            :updated ""}
                                                                                                                                                           :request_reference_split_the_bill [{:id 0
                                                                                                                                                                                               :type ""}]
                                                                                                                                                           :scheduled_id 0
                                                                                                                                                           :sub_type ""
                                                                                                                                                           :type ""
                                                                                                                                                           :updated ""}
                                                                                                                                                 :PaymentBatch {}}
                                                                                                                                        :recurrence_size 0
                                                                                                                                        :recurrence_unit ""
                                                                                                                                        :status ""
                                                                                                                                        :time_end ""
                                                                                                                                        :time_start ""}
                                                                                                                             :status ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"payment\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"allow_bunqto\": false,\n    \"amount\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"attachment\": [\n      {\n        \"id\": 0,\n        \"monetary_account_id\": 0\n      }\n    ],\n    \"counterparty_alias\": {},\n    \"description\": \"\",\n    \"merchant_reference\": \"\"\n  },\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"payment\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"allow_bunqto\": false,\n    \"amount\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"attachment\": [\n      {\n        \"id\": 0,\n        \"monetary_account_id\": 0\n      }\n    ],\n    \"counterparty_alias\": {},\n    \"description\": \"\",\n    \"merchant_reference\": \"\"\n  },\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"payment\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"allow_bunqto\": false,\n    \"amount\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"attachment\": [\n      {\n        \"id\": 0,\n        \"monetary_account_id\": 0\n      }\n    ],\n    \"counterparty_alias\": {},\n    \"description\": \"\",\n    \"merchant_reference\": \"\"\n  },\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment"

	payload := strings.NewReader("{\n  \"payment\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"allow_bunqto\": false,\n    \"amount\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"attachment\": [\n      {\n        \"id\": 0,\n        \"monetary_account_id\": 0\n      }\n    ],\n    \"counterparty_alias\": {},\n    \"description\": \"\",\n    \"merchant_reference\": \"\"\n  },\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 2897

{
  "payment": {
    "alias": {
      "avatar": {
        "anchor_uuid": "",
        "image": [
          {
            "attachment_public_uuid": "",
            "content_type": "",
            "height": 0,
            "width": 0
          }
        ],
        "style": "",
        "uuid": ""
      },
      "bunq_me": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "country": "",
      "display_name": "",
      "iban": "",
      "is_light": false,
      "label_user": {
        "avatar": {},
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "merchant_category_code": "",
      "swift_account_number": "",
      "swift_bic": "",
      "transferwise_account_number": "",
      "transferwise_bank_code": ""
    },
    "allow_bunqto": false,
    "amount": {
      "currency": "",
      "value": ""
    },
    "attachment": [
      {
        "id": 0,
        "monetary_account_id": 0
      }
    ],
    "counterparty_alias": {},
    "description": "",
    "merchant_reference": ""
  },
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  },
  "status": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"payment\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"allow_bunqto\": false,\n    \"amount\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"attachment\": [\n      {\n        \"id\": 0,\n        \"monetary_account_id\": 0\n      }\n    ],\n    \"counterparty_alias\": {},\n    \"description\": \"\",\n    \"merchant_reference\": \"\"\n  },\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"payment\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"allow_bunqto\": false,\n    \"amount\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"attachment\": [\n      {\n        \"id\": 0,\n        \"monetary_account_id\": 0\n      }\n    ],\n    \"counterparty_alias\": {},\n    \"description\": \"\",\n    \"merchant_reference\": \"\"\n  },\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"payment\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"allow_bunqto\": false,\n    \"amount\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"attachment\": [\n      {\n        \"id\": 0,\n        \"monetary_account_id\": 0\n      }\n    ],\n    \"counterparty_alias\": {},\n    \"description\": \"\",\n    \"merchant_reference\": \"\"\n  },\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"payment\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"allow_bunqto\": false,\n    \"amount\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"attachment\": [\n      {\n        \"id\": 0,\n        \"monetary_account_id\": 0\n      }\n    ],\n    \"counterparty_alias\": {},\n    \"description\": \"\",\n    \"merchant_reference\": \"\"\n  },\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  payment: {
    alias: {
      avatar: {
        anchor_uuid: '',
        image: [
          {
            attachment_public_uuid: '',
            content_type: '',
            height: 0,
            width: 0
          }
        ],
        style: '',
        uuid: ''
      },
      bunq_me: {
        name: '',
        service: '',
        type: '',
        value: ''
      },
      country: '',
      display_name: '',
      iban: '',
      is_light: false,
      label_user: {
        avatar: {},
        country: '',
        display_name: '',
        public_nick_name: '',
        uuid: ''
      },
      merchant_category_code: '',
      swift_account_number: '',
      swift_bic: '',
      transferwise_account_number: '',
      transferwise_bank_code: ''
    },
    allow_bunqto: false,
    amount: {
      currency: '',
      value: ''
    },
    attachment: [
      {
        id: 0,
        monetary_account_id: 0
      }
    ],
    counterparty_alias: {},
    description: '',
    merchant_reference: ''
  },
  schedule: {
    object: {
      Payment: {
        address_billing: {
          city: '',
          country: '',
          extra: '',
          house_number: '',
          is_user_address_updated: false,
          mailbox_name: '',
          po_box: '',
          postal_code: '',
          province: '',
          street: ''
        },
        address_shipping: {},
        alias: {},
        allow_bunqto: false,
        amount: {},
        attachment: [
          {}
        ],
        balance_after_mutation: {},
        batch_id: 0,
        bunqto_expiry: '',
        bunqto_share_url: '',
        bunqto_status: '',
        bunqto_sub_status: '',
        bunqto_time_responded: '',
        counterparty_alias: {},
        created: '',
        description: '',
        geolocation: {
          altitude: 0,
          latitude: 0,
          longitude: 0,
          radius: 0
        },
        id: 0,
        merchant_reference: '',
        monetary_account_id: 0,
        payment_auto_allocate_instance: {
          created: '',
          error_message: [],
          id: 0,
          payment_auto_allocate_id: 0,
          payment_batch: {
            payments: {
              Payment: []
            }
          },
          payment_id: 0,
          status: '',
          updated: ''
        },
        request_reference_split_the_bill: [
          {
            id: 0,
            type: ''
          }
        ],
        scheduled_id: 0,
        sub_type: '',
        type: '',
        updated: ''
      },
      PaymentBatch: {}
    },
    recurrence_size: 0,
    recurrence_unit: '',
    status: '',
    time_end: '',
    time_start: ''
  },
  status: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    payment: {
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
          style: '',
          uuid: ''
        },
        bunq_me: {name: '', service: '', type: '', value: ''},
        country: '',
        display_name: '',
        iban: '',
        is_light: false,
        label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
        merchant_category_code: '',
        swift_account_number: '',
        swift_bic: '',
        transferwise_account_number: '',
        transferwise_bank_code: ''
      },
      allow_bunqto: false,
      amount: {currency: '', value: ''},
      attachment: [{id: 0, monetary_account_id: 0}],
      counterparty_alias: {},
      description: '',
      merchant_reference: ''
    },
    schedule: {
      object: {
        Payment: {
          address_billing: {
            city: '',
            country: '',
            extra: '',
            house_number: '',
            is_user_address_updated: false,
            mailbox_name: '',
            po_box: '',
            postal_code: '',
            province: '',
            street: ''
          },
          address_shipping: {},
          alias: {},
          allow_bunqto: false,
          amount: {},
          attachment: [{}],
          balance_after_mutation: {},
          batch_id: 0,
          bunqto_expiry: '',
          bunqto_share_url: '',
          bunqto_status: '',
          bunqto_sub_status: '',
          bunqto_time_responded: '',
          counterparty_alias: {},
          created: '',
          description: '',
          geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
          id: 0,
          merchant_reference: '',
          monetary_account_id: 0,
          payment_auto_allocate_instance: {
            created: '',
            error_message: [],
            id: 0,
            payment_auto_allocate_id: 0,
            payment_batch: {payments: {Payment: []}},
            payment_id: 0,
            status: '',
            updated: ''
          },
          request_reference_split_the_bill: [{id: 0, type: ''}],
          scheduled_id: 0,
          sub_type: '',
          type: '',
          updated: ''
        },
        PaymentBatch: {}
      },
      recurrence_size: 0,
      recurrence_unit: '',
      status: '',
      time_end: '',
      time_start: ''
    },
    status: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"payment":{"alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"allow_bunqto":false,"amount":{"currency":"","value":""},"attachment":[{"id":0,"monetary_account_id":0}],"counterparty_alias":{},"description":"","merchant_reference":""},"schedule":{"object":{"Payment":{"address_billing":{"city":"","country":"","extra":"","house_number":"","is_user_address_updated":false,"mailbox_name":"","po_box":"","postal_code":"","province":"","street":""},"address_shipping":{},"alias":{},"allow_bunqto":false,"amount":{},"attachment":[{}],"balance_after_mutation":{},"batch_id":0,"bunqto_expiry":"","bunqto_share_url":"","bunqto_status":"","bunqto_sub_status":"","bunqto_time_responded":"","counterparty_alias":{},"created":"","description":"","geolocation":{"altitude":0,"latitude":0,"longitude":0,"radius":0},"id":0,"merchant_reference":"","monetary_account_id":0,"payment_auto_allocate_instance":{"created":"","error_message":[],"id":0,"payment_auto_allocate_id":0,"payment_batch":{"payments":{"Payment":[]}},"payment_id":0,"status":"","updated":""},"request_reference_split_the_bill":[{"id":0,"type":""}],"scheduled_id":0,"sub_type":"","type":"","updated":""},"PaymentBatch":{}},"recurrence_size":0,"recurrence_unit":"","status":"","time_end":"","time_start":""},"status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "payment": {\n    "alias": {\n      "avatar": {\n        "anchor_uuid": "",\n        "image": [\n          {\n            "attachment_public_uuid": "",\n            "content_type": "",\n            "height": 0,\n            "width": 0\n          }\n        ],\n        "style": "",\n        "uuid": ""\n      },\n      "bunq_me": {\n        "name": "",\n        "service": "",\n        "type": "",\n        "value": ""\n      },\n      "country": "",\n      "display_name": "",\n      "iban": "",\n      "is_light": false,\n      "label_user": {\n        "avatar": {},\n        "country": "",\n        "display_name": "",\n        "public_nick_name": "",\n        "uuid": ""\n      },\n      "merchant_category_code": "",\n      "swift_account_number": "",\n      "swift_bic": "",\n      "transferwise_account_number": "",\n      "transferwise_bank_code": ""\n    },\n    "allow_bunqto": false,\n    "amount": {\n      "currency": "",\n      "value": ""\n    },\n    "attachment": [\n      {\n        "id": 0,\n        "monetary_account_id": 0\n      }\n    ],\n    "counterparty_alias": {},\n    "description": "",\n    "merchant_reference": ""\n  },\n  "schedule": {\n    "object": {\n      "Payment": {\n        "address_billing": {\n          "city": "",\n          "country": "",\n          "extra": "",\n          "house_number": "",\n          "is_user_address_updated": false,\n          "mailbox_name": "",\n          "po_box": "",\n          "postal_code": "",\n          "province": "",\n          "street": ""\n        },\n        "address_shipping": {},\n        "alias": {},\n        "allow_bunqto": false,\n        "amount": {},\n        "attachment": [\n          {}\n        ],\n        "balance_after_mutation": {},\n        "batch_id": 0,\n        "bunqto_expiry": "",\n        "bunqto_share_url": "",\n        "bunqto_status": "",\n        "bunqto_sub_status": "",\n        "bunqto_time_responded": "",\n        "counterparty_alias": {},\n        "created": "",\n        "description": "",\n        "geolocation": {\n          "altitude": 0,\n          "latitude": 0,\n          "longitude": 0,\n          "radius": 0\n        },\n        "id": 0,\n        "merchant_reference": "",\n        "monetary_account_id": 0,\n        "payment_auto_allocate_instance": {\n          "created": "",\n          "error_message": [],\n          "id": 0,\n          "payment_auto_allocate_id": 0,\n          "payment_batch": {\n            "payments": {\n              "Payment": []\n            }\n          },\n          "payment_id": 0,\n          "status": "",\n          "updated": ""\n        },\n        "request_reference_split_the_bill": [\n          {\n            "id": 0,\n            "type": ""\n          }\n        ],\n        "scheduled_id": 0,\n        "sub_type": "",\n        "type": "",\n        "updated": ""\n      },\n      "PaymentBatch": {}\n    },\n    "recurrence_size": 0,\n    "recurrence_unit": "",\n    "status": "",\n    "time_end": "",\n    "time_start": ""\n  },\n  "status": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"payment\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"allow_bunqto\": false,\n    \"amount\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"attachment\": [\n      {\n        \"id\": 0,\n        \"monetary_account_id\": 0\n      }\n    ],\n    \"counterparty_alias\": {},\n    \"description\": \"\",\n    \"merchant_reference\": \"\"\n  },\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  payment: {
    alias: {
      avatar: {
        anchor_uuid: '',
        image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
        style: '',
        uuid: ''
      },
      bunq_me: {name: '', service: '', type: '', value: ''},
      country: '',
      display_name: '',
      iban: '',
      is_light: false,
      label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
      merchant_category_code: '',
      swift_account_number: '',
      swift_bic: '',
      transferwise_account_number: '',
      transferwise_bank_code: ''
    },
    allow_bunqto: false,
    amount: {currency: '', value: ''},
    attachment: [{id: 0, monetary_account_id: 0}],
    counterparty_alias: {},
    description: '',
    merchant_reference: ''
  },
  schedule: {
    object: {
      Payment: {
        address_billing: {
          city: '',
          country: '',
          extra: '',
          house_number: '',
          is_user_address_updated: false,
          mailbox_name: '',
          po_box: '',
          postal_code: '',
          province: '',
          street: ''
        },
        address_shipping: {},
        alias: {},
        allow_bunqto: false,
        amount: {},
        attachment: [{}],
        balance_after_mutation: {},
        batch_id: 0,
        bunqto_expiry: '',
        bunqto_share_url: '',
        bunqto_status: '',
        bunqto_sub_status: '',
        bunqto_time_responded: '',
        counterparty_alias: {},
        created: '',
        description: '',
        geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
        id: 0,
        merchant_reference: '',
        monetary_account_id: 0,
        payment_auto_allocate_instance: {
          created: '',
          error_message: [],
          id: 0,
          payment_auto_allocate_id: 0,
          payment_batch: {payments: {Payment: []}},
          payment_id: 0,
          status: '',
          updated: ''
        },
        request_reference_split_the_bill: [{id: 0, type: ''}],
        scheduled_id: 0,
        sub_type: '',
        type: '',
        updated: ''
      },
      PaymentBatch: {}
    },
    recurrence_size: 0,
    recurrence_unit: '',
    status: '',
    time_end: '',
    time_start: ''
  },
  status: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    payment: {
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
          style: '',
          uuid: ''
        },
        bunq_me: {name: '', service: '', type: '', value: ''},
        country: '',
        display_name: '',
        iban: '',
        is_light: false,
        label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
        merchant_category_code: '',
        swift_account_number: '',
        swift_bic: '',
        transferwise_account_number: '',
        transferwise_bank_code: ''
      },
      allow_bunqto: false,
      amount: {currency: '', value: ''},
      attachment: [{id: 0, monetary_account_id: 0}],
      counterparty_alias: {},
      description: '',
      merchant_reference: ''
    },
    schedule: {
      object: {
        Payment: {
          address_billing: {
            city: '',
            country: '',
            extra: '',
            house_number: '',
            is_user_address_updated: false,
            mailbox_name: '',
            po_box: '',
            postal_code: '',
            province: '',
            street: ''
          },
          address_shipping: {},
          alias: {},
          allow_bunqto: false,
          amount: {},
          attachment: [{}],
          balance_after_mutation: {},
          batch_id: 0,
          bunqto_expiry: '',
          bunqto_share_url: '',
          bunqto_status: '',
          bunqto_sub_status: '',
          bunqto_time_responded: '',
          counterparty_alias: {},
          created: '',
          description: '',
          geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
          id: 0,
          merchant_reference: '',
          monetary_account_id: 0,
          payment_auto_allocate_instance: {
            created: '',
            error_message: [],
            id: 0,
            payment_auto_allocate_id: 0,
            payment_batch: {payments: {Payment: []}},
            payment_id: 0,
            status: '',
            updated: ''
          },
          request_reference_split_the_bill: [{id: 0, type: ''}],
          scheduled_id: 0,
          sub_type: '',
          type: '',
          updated: ''
        },
        PaymentBatch: {}
      },
      recurrence_size: 0,
      recurrence_unit: '',
      status: '',
      time_end: '',
      time_start: ''
    },
    status: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  payment: {
    alias: {
      avatar: {
        anchor_uuid: '',
        image: [
          {
            attachment_public_uuid: '',
            content_type: '',
            height: 0,
            width: 0
          }
        ],
        style: '',
        uuid: ''
      },
      bunq_me: {
        name: '',
        service: '',
        type: '',
        value: ''
      },
      country: '',
      display_name: '',
      iban: '',
      is_light: false,
      label_user: {
        avatar: {},
        country: '',
        display_name: '',
        public_nick_name: '',
        uuid: ''
      },
      merchant_category_code: '',
      swift_account_number: '',
      swift_bic: '',
      transferwise_account_number: '',
      transferwise_bank_code: ''
    },
    allow_bunqto: false,
    amount: {
      currency: '',
      value: ''
    },
    attachment: [
      {
        id: 0,
        monetary_account_id: 0
      }
    ],
    counterparty_alias: {},
    description: '',
    merchant_reference: ''
  },
  schedule: {
    object: {
      Payment: {
        address_billing: {
          city: '',
          country: '',
          extra: '',
          house_number: '',
          is_user_address_updated: false,
          mailbox_name: '',
          po_box: '',
          postal_code: '',
          province: '',
          street: ''
        },
        address_shipping: {},
        alias: {},
        allow_bunqto: false,
        amount: {},
        attachment: [
          {}
        ],
        balance_after_mutation: {},
        batch_id: 0,
        bunqto_expiry: '',
        bunqto_share_url: '',
        bunqto_status: '',
        bunqto_sub_status: '',
        bunqto_time_responded: '',
        counterparty_alias: {},
        created: '',
        description: '',
        geolocation: {
          altitude: 0,
          latitude: 0,
          longitude: 0,
          radius: 0
        },
        id: 0,
        merchant_reference: '',
        monetary_account_id: 0,
        payment_auto_allocate_instance: {
          created: '',
          error_message: [],
          id: 0,
          payment_auto_allocate_id: 0,
          payment_batch: {
            payments: {
              Payment: []
            }
          },
          payment_id: 0,
          status: '',
          updated: ''
        },
        request_reference_split_the_bill: [
          {
            id: 0,
            type: ''
          }
        ],
        scheduled_id: 0,
        sub_type: '',
        type: '',
        updated: ''
      },
      PaymentBatch: {}
    },
    recurrence_size: 0,
    recurrence_unit: '',
    status: '',
    time_end: '',
    time_start: ''
  },
  status: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    payment: {
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
          style: '',
          uuid: ''
        },
        bunq_me: {name: '', service: '', type: '', value: ''},
        country: '',
        display_name: '',
        iban: '',
        is_light: false,
        label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
        merchant_category_code: '',
        swift_account_number: '',
        swift_bic: '',
        transferwise_account_number: '',
        transferwise_bank_code: ''
      },
      allow_bunqto: false,
      amount: {currency: '', value: ''},
      attachment: [{id: 0, monetary_account_id: 0}],
      counterparty_alias: {},
      description: '',
      merchant_reference: ''
    },
    schedule: {
      object: {
        Payment: {
          address_billing: {
            city: '',
            country: '',
            extra: '',
            house_number: '',
            is_user_address_updated: false,
            mailbox_name: '',
            po_box: '',
            postal_code: '',
            province: '',
            street: ''
          },
          address_shipping: {},
          alias: {},
          allow_bunqto: false,
          amount: {},
          attachment: [{}],
          balance_after_mutation: {},
          batch_id: 0,
          bunqto_expiry: '',
          bunqto_share_url: '',
          bunqto_status: '',
          bunqto_sub_status: '',
          bunqto_time_responded: '',
          counterparty_alias: {},
          created: '',
          description: '',
          geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
          id: 0,
          merchant_reference: '',
          monetary_account_id: 0,
          payment_auto_allocate_instance: {
            created: '',
            error_message: [],
            id: 0,
            payment_auto_allocate_id: 0,
            payment_batch: {payments: {Payment: []}},
            payment_id: 0,
            status: '',
            updated: ''
          },
          request_reference_split_the_bill: [{id: 0, type: ''}],
          scheduled_id: 0,
          sub_type: '',
          type: '',
          updated: ''
        },
        PaymentBatch: {}
      },
      recurrence_size: 0,
      recurrence_unit: '',
      status: '',
      time_end: '',
      time_start: ''
    },
    status: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"payment":{"alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"allow_bunqto":false,"amount":{"currency":"","value":""},"attachment":[{"id":0,"monetary_account_id":0}],"counterparty_alias":{},"description":"","merchant_reference":""},"schedule":{"object":{"Payment":{"address_billing":{"city":"","country":"","extra":"","house_number":"","is_user_address_updated":false,"mailbox_name":"","po_box":"","postal_code":"","province":"","street":""},"address_shipping":{},"alias":{},"allow_bunqto":false,"amount":{},"attachment":[{}],"balance_after_mutation":{},"batch_id":0,"bunqto_expiry":"","bunqto_share_url":"","bunqto_status":"","bunqto_sub_status":"","bunqto_time_responded":"","counterparty_alias":{},"created":"","description":"","geolocation":{"altitude":0,"latitude":0,"longitude":0,"radius":0},"id":0,"merchant_reference":"","monetary_account_id":0,"payment_auto_allocate_instance":{"created":"","error_message":[],"id":0,"payment_auto_allocate_id":0,"payment_batch":{"payments":{"Payment":[]}},"payment_id":0,"status":"","updated":""},"request_reference_split_the_bill":[{"id":0,"type":""}],"scheduled_id":0,"sub_type":"","type":"","updated":""},"PaymentBatch":{}},"recurrence_size":0,"recurrence_unit":"","status":"","time_end":"","time_start":""},"status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"payment": @{ @"alias": @{ @"avatar": @{ @"anchor_uuid": @"", @"image": @[ @{ @"attachment_public_uuid": @"", @"content_type": @"", @"height": @0, @"width": @0 } ], @"style": @"", @"uuid": @"" }, @"bunq_me": @{ @"name": @"", @"service": @"", @"type": @"", @"value": @"" }, @"country": @"", @"display_name": @"", @"iban": @"", @"is_light": @NO, @"label_user": @{ @"avatar": @{  }, @"country": @"", @"display_name": @"", @"public_nick_name": @"", @"uuid": @"" }, @"merchant_category_code": @"", @"swift_account_number": @"", @"swift_bic": @"", @"transferwise_account_number": @"", @"transferwise_bank_code": @"" }, @"allow_bunqto": @NO, @"amount": @{ @"currency": @"", @"value": @"" }, @"attachment": @[ @{ @"id": @0, @"monetary_account_id": @0 } ], @"counterparty_alias": @{  }, @"description": @"", @"merchant_reference": @"" },
                              @"schedule": @{ @"object": @{ @"Payment": @{ @"address_billing": @{ @"city": @"", @"country": @"", @"extra": @"", @"house_number": @"", @"is_user_address_updated": @NO, @"mailbox_name": @"", @"po_box": @"", @"postal_code": @"", @"province": @"", @"street": @"" }, @"address_shipping": @{  }, @"alias": @{  }, @"allow_bunqto": @NO, @"amount": @{  }, @"attachment": @[ @{  } ], @"balance_after_mutation": @{  }, @"batch_id": @0, @"bunqto_expiry": @"", @"bunqto_share_url": @"", @"bunqto_status": @"", @"bunqto_sub_status": @"", @"bunqto_time_responded": @"", @"counterparty_alias": @{  }, @"created": @"", @"description": @"", @"geolocation": @{ @"altitude": @0, @"latitude": @0, @"longitude": @0, @"radius": @0 }, @"id": @0, @"merchant_reference": @"", @"monetary_account_id": @0, @"payment_auto_allocate_instance": @{ @"created": @"", @"error_message": @[  ], @"id": @0, @"payment_auto_allocate_id": @0, @"payment_batch": @{ @"payments": @{ @"Payment": @[  ] } }, @"payment_id": @0, @"status": @"", @"updated": @"" }, @"request_reference_split_the_bill": @[ @{ @"id": @0, @"type": @"" } ], @"scheduled_id": @0, @"sub_type": @"", @"type": @"", @"updated": @"" }, @"PaymentBatch": @{  } }, @"recurrence_size": @0, @"recurrence_unit": @"", @"status": @"", @"time_end": @"", @"time_start": @"" },
                              @"status": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"payment\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"allow_bunqto\": false,\n    \"amount\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"attachment\": [\n      {\n        \"id\": 0,\n        \"monetary_account_id\": 0\n      }\n    ],\n    \"counterparty_alias\": {},\n    \"description\": \"\",\n    \"merchant_reference\": \"\"\n  },\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'payment' => [
        'alias' => [
                'avatar' => [
                                'anchor_uuid' => '',
                                'image' => [
                                                                [
                                                                                                                                'attachment_public_uuid' => '',
                                                                                                                                'content_type' => '',
                                                                                                                                'height' => 0,
                                                                                                                                'width' => 0
                                                                ]
                                ],
                                'style' => '',
                                'uuid' => ''
                ],
                'bunq_me' => [
                                'name' => '',
                                'service' => '',
                                'type' => '',
                                'value' => ''
                ],
                'country' => '',
                'display_name' => '',
                'iban' => '',
                'is_light' => null,
                'label_user' => [
                                'avatar' => [
                                                                
                                ],
                                'country' => '',
                                'display_name' => '',
                                'public_nick_name' => '',
                                'uuid' => ''
                ],
                'merchant_category_code' => '',
                'swift_account_number' => '',
                'swift_bic' => '',
                'transferwise_account_number' => '',
                'transferwise_bank_code' => ''
        ],
        'allow_bunqto' => null,
        'amount' => [
                'currency' => '',
                'value' => ''
        ],
        'attachment' => [
                [
                                'id' => 0,
                                'monetary_account_id' => 0
                ]
        ],
        'counterparty_alias' => [
                
        ],
        'description' => '',
        'merchant_reference' => ''
    ],
    'schedule' => [
        'object' => [
                'Payment' => [
                                'address_billing' => [
                                                                'city' => '',
                                                                'country' => '',
                                                                'extra' => '',
                                                                'house_number' => '',
                                                                'is_user_address_updated' => null,
                                                                'mailbox_name' => '',
                                                                'po_box' => '',
                                                                'postal_code' => '',
                                                                'province' => '',
                                                                'street' => ''
                                ],
                                'address_shipping' => [
                                                                
                                ],
                                'alias' => [
                                                                
                                ],
                                'allow_bunqto' => null,
                                'amount' => [
                                                                
                                ],
                                'attachment' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'balance_after_mutation' => [
                                                                
                                ],
                                'batch_id' => 0,
                                'bunqto_expiry' => '',
                                'bunqto_share_url' => '',
                                'bunqto_status' => '',
                                'bunqto_sub_status' => '',
                                'bunqto_time_responded' => '',
                                'counterparty_alias' => [
                                                                
                                ],
                                'created' => '',
                                'description' => '',
                                'geolocation' => [
                                                                'altitude' => 0,
                                                                'latitude' => 0,
                                                                'longitude' => 0,
                                                                'radius' => 0
                                ],
                                'id' => 0,
                                'merchant_reference' => '',
                                'monetary_account_id' => 0,
                                'payment_auto_allocate_instance' => [
                                                                'created' => '',
                                                                'error_message' => [
                                                                                                                                
                                                                ],
                                                                'id' => 0,
                                                                'payment_auto_allocate_id' => 0,
                                                                'payment_batch' => [
                                                                                                                                'payments' => [
                                                                                                                                                                                                                                                                'Payment' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ]
                                                                                                                                ]
                                                                ],
                                                                'payment_id' => 0,
                                                                'status' => '',
                                                                'updated' => ''
                                ],
                                'request_reference_split_the_bill' => [
                                                                [
                                                                                                                                'id' => 0,
                                                                                                                                'type' => ''
                                                                ]
                                ],
                                'scheduled_id' => 0,
                                'sub_type' => '',
                                'type' => '',
                                'updated' => ''
                ],
                'PaymentBatch' => [
                                
                ]
        ],
        'recurrence_size' => 0,
        'recurrence_unit' => '',
        'status' => '',
        'time_end' => '',
        'time_start' => ''
    ],
    'status' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment', [
  'body' => '{
  "payment": {
    "alias": {
      "avatar": {
        "anchor_uuid": "",
        "image": [
          {
            "attachment_public_uuid": "",
            "content_type": "",
            "height": 0,
            "width": 0
          }
        ],
        "style": "",
        "uuid": ""
      },
      "bunq_me": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "country": "",
      "display_name": "",
      "iban": "",
      "is_light": false,
      "label_user": {
        "avatar": {},
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "merchant_category_code": "",
      "swift_account_number": "",
      "swift_bic": "",
      "transferwise_account_number": "",
      "transferwise_bank_code": ""
    },
    "allow_bunqto": false,
    "amount": {
      "currency": "",
      "value": ""
    },
    "attachment": [
      {
        "id": 0,
        "monetary_account_id": 0
      }
    ],
    "counterparty_alias": {},
    "description": "",
    "merchant_reference": ""
  },
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  },
  "status": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'payment' => [
    'alias' => [
        'avatar' => [
                'anchor_uuid' => '',
                'image' => [
                                [
                                                                'attachment_public_uuid' => '',
                                                                'content_type' => '',
                                                                'height' => 0,
                                                                'width' => 0
                                ]
                ],
                'style' => '',
                'uuid' => ''
        ],
        'bunq_me' => [
                'name' => '',
                'service' => '',
                'type' => '',
                'value' => ''
        ],
        'country' => '',
        'display_name' => '',
        'iban' => '',
        'is_light' => null,
        'label_user' => [
                'avatar' => [
                                
                ],
                'country' => '',
                'display_name' => '',
                'public_nick_name' => '',
                'uuid' => ''
        ],
        'merchant_category_code' => '',
        'swift_account_number' => '',
        'swift_bic' => '',
        'transferwise_account_number' => '',
        'transferwise_bank_code' => ''
    ],
    'allow_bunqto' => null,
    'amount' => [
        'currency' => '',
        'value' => ''
    ],
    'attachment' => [
        [
                'id' => 0,
                'monetary_account_id' => 0
        ]
    ],
    'counterparty_alias' => [
        
    ],
    'description' => '',
    'merchant_reference' => ''
  ],
  'schedule' => [
    'object' => [
        'Payment' => [
                'address_billing' => [
                                'city' => '',
                                'country' => '',
                                'extra' => '',
                                'house_number' => '',
                                'is_user_address_updated' => null,
                                'mailbox_name' => '',
                                'po_box' => '',
                                'postal_code' => '',
                                'province' => '',
                                'street' => ''
                ],
                'address_shipping' => [
                                
                ],
                'alias' => [
                                
                ],
                'allow_bunqto' => null,
                'amount' => [
                                
                ],
                'attachment' => [
                                [
                                                                
                                ]
                ],
                'balance_after_mutation' => [
                                
                ],
                'batch_id' => 0,
                'bunqto_expiry' => '',
                'bunqto_share_url' => '',
                'bunqto_status' => '',
                'bunqto_sub_status' => '',
                'bunqto_time_responded' => '',
                'counterparty_alias' => [
                                
                ],
                'created' => '',
                'description' => '',
                'geolocation' => [
                                'altitude' => 0,
                                'latitude' => 0,
                                'longitude' => 0,
                                'radius' => 0
                ],
                'id' => 0,
                'merchant_reference' => '',
                'monetary_account_id' => 0,
                'payment_auto_allocate_instance' => [
                                'created' => '',
                                'error_message' => [
                                                                
                                ],
                                'id' => 0,
                                'payment_auto_allocate_id' => 0,
                                'payment_batch' => [
                                                                'payments' => [
                                                                                                                                'Payment' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'payment_id' => 0,
                                'status' => '',
                                'updated' => ''
                ],
                'request_reference_split_the_bill' => [
                                [
                                                                'id' => 0,
                                                                'type' => ''
                                ]
                ],
                'scheduled_id' => 0,
                'sub_type' => '',
                'type' => '',
                'updated' => ''
        ],
        'PaymentBatch' => [
                
        ]
    ],
    'recurrence_size' => 0,
    'recurrence_unit' => '',
    'status' => '',
    'time_end' => '',
    'time_start' => ''
  ],
  'status' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'payment' => [
    'alias' => [
        'avatar' => [
                'anchor_uuid' => '',
                'image' => [
                                [
                                                                'attachment_public_uuid' => '',
                                                                'content_type' => '',
                                                                'height' => 0,
                                                                'width' => 0
                                ]
                ],
                'style' => '',
                'uuid' => ''
        ],
        'bunq_me' => [
                'name' => '',
                'service' => '',
                'type' => '',
                'value' => ''
        ],
        'country' => '',
        'display_name' => '',
        'iban' => '',
        'is_light' => null,
        'label_user' => [
                'avatar' => [
                                
                ],
                'country' => '',
                'display_name' => '',
                'public_nick_name' => '',
                'uuid' => ''
        ],
        'merchant_category_code' => '',
        'swift_account_number' => '',
        'swift_bic' => '',
        'transferwise_account_number' => '',
        'transferwise_bank_code' => ''
    ],
    'allow_bunqto' => null,
    'amount' => [
        'currency' => '',
        'value' => ''
    ],
    'attachment' => [
        [
                'id' => 0,
                'monetary_account_id' => 0
        ]
    ],
    'counterparty_alias' => [
        
    ],
    'description' => '',
    'merchant_reference' => ''
  ],
  'schedule' => [
    'object' => [
        'Payment' => [
                'address_billing' => [
                                'city' => '',
                                'country' => '',
                                'extra' => '',
                                'house_number' => '',
                                'is_user_address_updated' => null,
                                'mailbox_name' => '',
                                'po_box' => '',
                                'postal_code' => '',
                                'province' => '',
                                'street' => ''
                ],
                'address_shipping' => [
                                
                ],
                'alias' => [
                                
                ],
                'allow_bunqto' => null,
                'amount' => [
                                
                ],
                'attachment' => [
                                [
                                                                
                                ]
                ],
                'balance_after_mutation' => [
                                
                ],
                'batch_id' => 0,
                'bunqto_expiry' => '',
                'bunqto_share_url' => '',
                'bunqto_status' => '',
                'bunqto_sub_status' => '',
                'bunqto_time_responded' => '',
                'counterparty_alias' => [
                                
                ],
                'created' => '',
                'description' => '',
                'geolocation' => [
                                'altitude' => 0,
                                'latitude' => 0,
                                'longitude' => 0,
                                'radius' => 0
                ],
                'id' => 0,
                'merchant_reference' => '',
                'monetary_account_id' => 0,
                'payment_auto_allocate_instance' => [
                                'created' => '',
                                'error_message' => [
                                                                
                                ],
                                'id' => 0,
                                'payment_auto_allocate_id' => 0,
                                'payment_batch' => [
                                                                'payments' => [
                                                                                                                                'Payment' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'payment_id' => 0,
                                'status' => '',
                                'updated' => ''
                ],
                'request_reference_split_the_bill' => [
                                [
                                                                'id' => 0,
                                                                'type' => ''
                                ]
                ],
                'scheduled_id' => 0,
                'sub_type' => '',
                'type' => '',
                'updated' => ''
        ],
        'PaymentBatch' => [
                
        ]
    ],
    'recurrence_size' => 0,
    'recurrence_unit' => '',
    'status' => '',
    'time_end' => '',
    'time_start' => ''
  ],
  'status' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "payment": {
    "alias": {
      "avatar": {
        "anchor_uuid": "",
        "image": [
          {
            "attachment_public_uuid": "",
            "content_type": "",
            "height": 0,
            "width": 0
          }
        ],
        "style": "",
        "uuid": ""
      },
      "bunq_me": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "country": "",
      "display_name": "",
      "iban": "",
      "is_light": false,
      "label_user": {
        "avatar": {},
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "merchant_category_code": "",
      "swift_account_number": "",
      "swift_bic": "",
      "transferwise_account_number": "",
      "transferwise_bank_code": ""
    },
    "allow_bunqto": false,
    "amount": {
      "currency": "",
      "value": ""
    },
    "attachment": [
      {
        "id": 0,
        "monetary_account_id": 0
      }
    ],
    "counterparty_alias": {},
    "description": "",
    "merchant_reference": ""
  },
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  },
  "status": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "payment": {
    "alias": {
      "avatar": {
        "anchor_uuid": "",
        "image": [
          {
            "attachment_public_uuid": "",
            "content_type": "",
            "height": 0,
            "width": 0
          }
        ],
        "style": "",
        "uuid": ""
      },
      "bunq_me": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "country": "",
      "display_name": "",
      "iban": "",
      "is_light": false,
      "label_user": {
        "avatar": {},
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "merchant_category_code": "",
      "swift_account_number": "",
      "swift_bic": "",
      "transferwise_account_number": "",
      "transferwise_bank_code": ""
    },
    "allow_bunqto": false,
    "amount": {
      "currency": "",
      "value": ""
    },
    "attachment": [
      {
        "id": 0,
        "monetary_account_id": 0
      }
    ],
    "counterparty_alias": {},
    "description": "",
    "merchant_reference": ""
  },
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  },
  "status": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"payment\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"allow_bunqto\": false,\n    \"amount\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"attachment\": [\n      {\n        \"id\": 0,\n        \"monetary_account_id\": 0\n      }\n    ],\n    \"counterparty_alias\": {},\n    \"description\": \"\",\n    \"merchant_reference\": \"\"\n  },\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment"

payload = {
    "payment": {
        "alias": {
            "avatar": {
                "anchor_uuid": "",
                "image": [
                    {
                        "attachment_public_uuid": "",
                        "content_type": "",
                        "height": 0,
                        "width": 0
                    }
                ],
                "style": "",
                "uuid": ""
            },
            "bunq_me": {
                "name": "",
                "service": "",
                "type": "",
                "value": ""
            },
            "country": "",
            "display_name": "",
            "iban": "",
            "is_light": False,
            "label_user": {
                "avatar": {},
                "country": "",
                "display_name": "",
                "public_nick_name": "",
                "uuid": ""
            },
            "merchant_category_code": "",
            "swift_account_number": "",
            "swift_bic": "",
            "transferwise_account_number": "",
            "transferwise_bank_code": ""
        },
        "allow_bunqto": False,
        "amount": {
            "currency": "",
            "value": ""
        },
        "attachment": [
            {
                "id": 0,
                "monetary_account_id": 0
            }
        ],
        "counterparty_alias": {},
        "description": "",
        "merchant_reference": ""
    },
    "schedule": {
        "object": {
            "Payment": {
                "address_billing": {
                    "city": "",
                    "country": "",
                    "extra": "",
                    "house_number": "",
                    "is_user_address_updated": False,
                    "mailbox_name": "",
                    "po_box": "",
                    "postal_code": "",
                    "province": "",
                    "street": ""
                },
                "address_shipping": {},
                "alias": {},
                "allow_bunqto": False,
                "amount": {},
                "attachment": [{}],
                "balance_after_mutation": {},
                "batch_id": 0,
                "bunqto_expiry": "",
                "bunqto_share_url": "",
                "bunqto_status": "",
                "bunqto_sub_status": "",
                "bunqto_time_responded": "",
                "counterparty_alias": {},
                "created": "",
                "description": "",
                "geolocation": {
                    "altitude": 0,
                    "latitude": 0,
                    "longitude": 0,
                    "radius": 0
                },
                "id": 0,
                "merchant_reference": "",
                "monetary_account_id": 0,
                "payment_auto_allocate_instance": {
                    "created": "",
                    "error_message": [],
                    "id": 0,
                    "payment_auto_allocate_id": 0,
                    "payment_batch": { "payments": { "Payment": [] } },
                    "payment_id": 0,
                    "status": "",
                    "updated": ""
                },
                "request_reference_split_the_bill": [
                    {
                        "id": 0,
                        "type": ""
                    }
                ],
                "scheduled_id": 0,
                "sub_type": "",
                "type": "",
                "updated": ""
            },
            "PaymentBatch": {}
        },
        "recurrence_size": 0,
        "recurrence_unit": "",
        "status": "",
        "time_end": "",
        "time_start": ""
    },
    "status": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment"

payload <- "{\n  \"payment\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"allow_bunqto\": false,\n    \"amount\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"attachment\": [\n      {\n        \"id\": 0,\n        \"monetary_account_id\": 0\n      }\n    ],\n    \"counterparty_alias\": {},\n    \"description\": \"\",\n    \"merchant_reference\": \"\"\n  },\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"payment\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"allow_bunqto\": false,\n    \"amount\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"attachment\": [\n      {\n        \"id\": 0,\n        \"monetary_account_id\": 0\n      }\n    ],\n    \"counterparty_alias\": {},\n    \"description\": \"\",\n    \"merchant_reference\": \"\"\n  },\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"payment\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"allow_bunqto\": false,\n    \"amount\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"attachment\": [\n      {\n        \"id\": 0,\n        \"monetary_account_id\": 0\n      }\n    ],\n    \"counterparty_alias\": {},\n    \"description\": \"\",\n    \"merchant_reference\": \"\"\n  },\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment";

    let payload = json!({
        "payment": json!({
            "alias": json!({
                "avatar": json!({
                    "anchor_uuid": "",
                    "image": (
                        json!({
                            "attachment_public_uuid": "",
                            "content_type": "",
                            "height": 0,
                            "width": 0
                        })
                    ),
                    "style": "",
                    "uuid": ""
                }),
                "bunq_me": json!({
                    "name": "",
                    "service": "",
                    "type": "",
                    "value": ""
                }),
                "country": "",
                "display_name": "",
                "iban": "",
                "is_light": false,
                "label_user": json!({
                    "avatar": json!({}),
                    "country": "",
                    "display_name": "",
                    "public_nick_name": "",
                    "uuid": ""
                }),
                "merchant_category_code": "",
                "swift_account_number": "",
                "swift_bic": "",
                "transferwise_account_number": "",
                "transferwise_bank_code": ""
            }),
            "allow_bunqto": false,
            "amount": json!({
                "currency": "",
                "value": ""
            }),
            "attachment": (
                json!({
                    "id": 0,
                    "monetary_account_id": 0
                })
            ),
            "counterparty_alias": json!({}),
            "description": "",
            "merchant_reference": ""
        }),
        "schedule": json!({
            "object": json!({
                "Payment": json!({
                    "address_billing": json!({
                        "city": "",
                        "country": "",
                        "extra": "",
                        "house_number": "",
                        "is_user_address_updated": false,
                        "mailbox_name": "",
                        "po_box": "",
                        "postal_code": "",
                        "province": "",
                        "street": ""
                    }),
                    "address_shipping": json!({}),
                    "alias": json!({}),
                    "allow_bunqto": false,
                    "amount": json!({}),
                    "attachment": (json!({})),
                    "balance_after_mutation": json!({}),
                    "batch_id": 0,
                    "bunqto_expiry": "",
                    "bunqto_share_url": "",
                    "bunqto_status": "",
                    "bunqto_sub_status": "",
                    "bunqto_time_responded": "",
                    "counterparty_alias": json!({}),
                    "created": "",
                    "description": "",
                    "geolocation": json!({
                        "altitude": 0,
                        "latitude": 0,
                        "longitude": 0,
                        "radius": 0
                    }),
                    "id": 0,
                    "merchant_reference": "",
                    "monetary_account_id": 0,
                    "payment_auto_allocate_instance": json!({
                        "created": "",
                        "error_message": (),
                        "id": 0,
                        "payment_auto_allocate_id": 0,
                        "payment_batch": json!({"payments": json!({"Payment": ()})}),
                        "payment_id": 0,
                        "status": "",
                        "updated": ""
                    }),
                    "request_reference_split_the_bill": (
                        json!({
                            "id": 0,
                            "type": ""
                        })
                    ),
                    "scheduled_id": 0,
                    "sub_type": "",
                    "type": "",
                    "updated": ""
                }),
                "PaymentBatch": json!({})
            }),
            "recurrence_size": 0,
            "recurrence_unit": "",
            "status": "",
            "time_end": "",
            "time_start": ""
        }),
        "status": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "payment": {
    "alias": {
      "avatar": {
        "anchor_uuid": "",
        "image": [
          {
            "attachment_public_uuid": "",
            "content_type": "",
            "height": 0,
            "width": 0
          }
        ],
        "style": "",
        "uuid": ""
      },
      "bunq_me": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "country": "",
      "display_name": "",
      "iban": "",
      "is_light": false,
      "label_user": {
        "avatar": {},
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "merchant_category_code": "",
      "swift_account_number": "",
      "swift_bic": "",
      "transferwise_account_number": "",
      "transferwise_bank_code": ""
    },
    "allow_bunqto": false,
    "amount": {
      "currency": "",
      "value": ""
    },
    "attachment": [
      {
        "id": 0,
        "monetary_account_id": 0
      }
    ],
    "counterparty_alias": {},
    "description": "",
    "merchant_reference": ""
  },
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  },
  "status": ""
}'
echo '{
  "payment": {
    "alias": {
      "avatar": {
        "anchor_uuid": "",
        "image": [
          {
            "attachment_public_uuid": "",
            "content_type": "",
            "height": 0,
            "width": 0
          }
        ],
        "style": "",
        "uuid": ""
      },
      "bunq_me": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "country": "",
      "display_name": "",
      "iban": "",
      "is_light": false,
      "label_user": {
        "avatar": {},
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "merchant_category_code": "",
      "swift_account_number": "",
      "swift_bic": "",
      "transferwise_account_number": "",
      "transferwise_bank_code": ""
    },
    "allow_bunqto": false,
    "amount": {
      "currency": "",
      "value": ""
    },
    "attachment": [
      {
        "id": 0,
        "monetary_account_id": 0
      }
    ],
    "counterparty_alias": {},
    "description": "",
    "merchant_reference": ""
  },
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  },
  "status": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "payment": {\n    "alias": {\n      "avatar": {\n        "anchor_uuid": "",\n        "image": [\n          {\n            "attachment_public_uuid": "",\n            "content_type": "",\n            "height": 0,\n            "width": 0\n          }\n        ],\n        "style": "",\n        "uuid": ""\n      },\n      "bunq_me": {\n        "name": "",\n        "service": "",\n        "type": "",\n        "value": ""\n      },\n      "country": "",\n      "display_name": "",\n      "iban": "",\n      "is_light": false,\n      "label_user": {\n        "avatar": {},\n        "country": "",\n        "display_name": "",\n        "public_nick_name": "",\n        "uuid": ""\n      },\n      "merchant_category_code": "",\n      "swift_account_number": "",\n      "swift_bic": "",\n      "transferwise_account_number": "",\n      "transferwise_bank_code": ""\n    },\n    "allow_bunqto": false,\n    "amount": {\n      "currency": "",\n      "value": ""\n    },\n    "attachment": [\n      {\n        "id": 0,\n        "monetary_account_id": 0\n      }\n    ],\n    "counterparty_alias": {},\n    "description": "",\n    "merchant_reference": ""\n  },\n  "schedule": {\n    "object": {\n      "Payment": {\n        "address_billing": {\n          "city": "",\n          "country": "",\n          "extra": "",\n          "house_number": "",\n          "is_user_address_updated": false,\n          "mailbox_name": "",\n          "po_box": "",\n          "postal_code": "",\n          "province": "",\n          "street": ""\n        },\n        "address_shipping": {},\n        "alias": {},\n        "allow_bunqto": false,\n        "amount": {},\n        "attachment": [\n          {}\n        ],\n        "balance_after_mutation": {},\n        "batch_id": 0,\n        "bunqto_expiry": "",\n        "bunqto_share_url": "",\n        "bunqto_status": "",\n        "bunqto_sub_status": "",\n        "bunqto_time_responded": "",\n        "counterparty_alias": {},\n        "created": "",\n        "description": "",\n        "geolocation": {\n          "altitude": 0,\n          "latitude": 0,\n          "longitude": 0,\n          "radius": 0\n        },\n        "id": 0,\n        "merchant_reference": "",\n        "monetary_account_id": 0,\n        "payment_auto_allocate_instance": {\n          "created": "",\n          "error_message": [],\n          "id": 0,\n          "payment_auto_allocate_id": 0,\n          "payment_batch": {\n            "payments": {\n              "Payment": []\n            }\n          },\n          "payment_id": 0,\n          "status": "",\n          "updated": ""\n        },\n        "request_reference_split_the_bill": [\n          {\n            "id": 0,\n            "type": ""\n          }\n        ],\n        "scheduled_id": 0,\n        "sub_type": "",\n        "type": "",\n        "updated": ""\n      },\n      "PaymentBatch": {}\n    },\n    "recurrence_size": 0,\n    "recurrence_unit": "",\n    "status": "",\n    "time_end": "",\n    "time_start": ""\n  },\n  "status": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "payment": [
    "alias": [
      "avatar": [
        "anchor_uuid": "",
        "image": [
          [
            "attachment_public_uuid": "",
            "content_type": "",
            "height": 0,
            "width": 0
          ]
        ],
        "style": "",
        "uuid": ""
      ],
      "bunq_me": [
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      ],
      "country": "",
      "display_name": "",
      "iban": "",
      "is_light": false,
      "label_user": [
        "avatar": [],
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      ],
      "merchant_category_code": "",
      "swift_account_number": "",
      "swift_bic": "",
      "transferwise_account_number": "",
      "transferwise_bank_code": ""
    ],
    "allow_bunqto": false,
    "amount": [
      "currency": "",
      "value": ""
    ],
    "attachment": [
      [
        "id": 0,
        "monetary_account_id": 0
      ]
    ],
    "counterparty_alias": [],
    "description": "",
    "merchant_reference": ""
  ],
  "schedule": [
    "object": [
      "Payment": [
        "address_billing": [
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        ],
        "address_shipping": [],
        "alias": [],
        "allow_bunqto": false,
        "amount": [],
        "attachment": [[]],
        "balance_after_mutation": [],
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": [],
        "created": "",
        "description": "",
        "geolocation": [
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        ],
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": [
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": ["payments": ["Payment": []]],
          "payment_id": 0,
          "status": "",
          "updated": ""
        ],
        "request_reference_split_the_bill": [
          [
            "id": 0,
            "type": ""
          ]
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      ],
      "PaymentBatch": []
    ],
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  ],
  "status": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_SchedulePayment_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId" {:headers {:user-agent ""
                                                                                                                                   :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId"]
                                                       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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_SchedulePayment_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment" {:headers {:user-agent ""
                                                                                                                        :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_SchedulePayment_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId" {:headers {:user-agent ""
                                                                                                                                :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_SchedulePayment_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
itemId
BODY json

{
  "payment": {
    "alias": {
      "avatar": {
        "anchor_uuid": "",
        "image": [
          {
            "attachment_public_uuid": "",
            "content_type": "",
            "height": 0,
            "width": 0
          }
        ],
        "style": "",
        "uuid": ""
      },
      "bunq_me": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "country": "",
      "display_name": "",
      "iban": "",
      "is_light": false,
      "label_user": {
        "avatar": {},
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "merchant_category_code": "",
      "swift_account_number": "",
      "swift_bic": "",
      "transferwise_account_number": "",
      "transferwise_bank_code": ""
    },
    "allow_bunqto": false,
    "amount": {
      "currency": "",
      "value": ""
    },
    "attachment": [
      {
        "id": 0,
        "monetary_account_id": 0
      }
    ],
    "counterparty_alias": {},
    "description": "",
    "merchant_reference": ""
  },
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  },
  "status": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"payment\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"allow_bunqto\": false,\n    \"amount\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"attachment\": [\n      {\n        \"id\": 0,\n        \"monetary_account_id\": 0\n      }\n    ],\n    \"counterparty_alias\": {},\n    \"description\": \"\",\n    \"merchant_reference\": \"\"\n  },\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId" {:headers {:user-agent ""
                                                                                                                                :x-bunq-client-authentication ""}
                                                                                                                      :content-type :json
                                                                                                                      :form-params {:payment {:alias {:avatar {:anchor_uuid ""
                                                                                                                                                               :image [{:attachment_public_uuid ""
                                                                                                                                                                        :content_type ""
                                                                                                                                                                        :height 0
                                                                                                                                                                        :width 0}]
                                                                                                                                                               :style ""
                                                                                                                                                               :uuid ""}
                                                                                                                                                      :bunq_me {:name ""
                                                                                                                                                                :service ""
                                                                                                                                                                :type ""
                                                                                                                                                                :value ""}
                                                                                                                                                      :country ""
                                                                                                                                                      :display_name ""
                                                                                                                                                      :iban ""
                                                                                                                                                      :is_light false
                                                                                                                                                      :label_user {:avatar {}
                                                                                                                                                                   :country ""
                                                                                                                                                                   :display_name ""
                                                                                                                                                                   :public_nick_name ""
                                                                                                                                                                   :uuid ""}
                                                                                                                                                      :merchant_category_code ""
                                                                                                                                                      :swift_account_number ""
                                                                                                                                                      :swift_bic ""
                                                                                                                                                      :transferwise_account_number ""
                                                                                                                                                      :transferwise_bank_code ""}
                                                                                                                                              :allow_bunqto false
                                                                                                                                              :amount {:currency ""
                                                                                                                                                       :value ""}
                                                                                                                                              :attachment [{:id 0
                                                                                                                                                            :monetary_account_id 0}]
                                                                                                                                              :counterparty_alias {}
                                                                                                                                              :description ""
                                                                                                                                              :merchant_reference ""}
                                                                                                                                    :schedule {:object {:Payment {:address_billing {:city ""
                                                                                                                                                                                    :country ""
                                                                                                                                                                                    :extra ""
                                                                                                                                                                                    :house_number ""
                                                                                                                                                                                    :is_user_address_updated false
                                                                                                                                                                                    :mailbox_name ""
                                                                                                                                                                                    :po_box ""
                                                                                                                                                                                    :postal_code ""
                                                                                                                                                                                    :province ""
                                                                                                                                                                                    :street ""}
                                                                                                                                                                  :address_shipping {}
                                                                                                                                                                  :alias {}
                                                                                                                                                                  :allow_bunqto false
                                                                                                                                                                  :amount {}
                                                                                                                                                                  :attachment [{}]
                                                                                                                                                                  :balance_after_mutation {}
                                                                                                                                                                  :batch_id 0
                                                                                                                                                                  :bunqto_expiry ""
                                                                                                                                                                  :bunqto_share_url ""
                                                                                                                                                                  :bunqto_status ""
                                                                                                                                                                  :bunqto_sub_status ""
                                                                                                                                                                  :bunqto_time_responded ""
                                                                                                                                                                  :counterparty_alias {}
                                                                                                                                                                  :created ""
                                                                                                                                                                  :description ""
                                                                                                                                                                  :geolocation {:altitude 0
                                                                                                                                                                                :latitude 0
                                                                                                                                                                                :longitude 0
                                                                                                                                                                                :radius 0}
                                                                                                                                                                  :id 0
                                                                                                                                                                  :merchant_reference ""
                                                                                                                                                                  :monetary_account_id 0
                                                                                                                                                                  :payment_auto_allocate_instance {:created ""
                                                                                                                                                                                                   :error_message []
                                                                                                                                                                                                   :id 0
                                                                                                                                                                                                   :payment_auto_allocate_id 0
                                                                                                                                                                                                   :payment_batch {:payments {:Payment []}}
                                                                                                                                                                                                   :payment_id 0
                                                                                                                                                                                                   :status ""
                                                                                                                                                                                                   :updated ""}
                                                                                                                                                                  :request_reference_split_the_bill [{:id 0
                                                                                                                                                                                                      :type ""}]
                                                                                                                                                                  :scheduled_id 0
                                                                                                                                                                  :sub_type ""
                                                                                                                                                                  :type ""
                                                                                                                                                                  :updated ""}
                                                                                                                                                        :PaymentBatch {}}
                                                                                                                                               :recurrence_size 0
                                                                                                                                               :recurrence_unit ""
                                                                                                                                               :status ""
                                                                                                                                               :time_end ""
                                                                                                                                               :time_start ""}
                                                                                                                                    :status ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"payment\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"allow_bunqto\": false,\n    \"amount\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"attachment\": [\n      {\n        \"id\": 0,\n        \"monetary_account_id\": 0\n      }\n    ],\n    \"counterparty_alias\": {},\n    \"description\": \"\",\n    \"merchant_reference\": \"\"\n  },\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"payment\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"allow_bunqto\": false,\n    \"amount\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"attachment\": [\n      {\n        \"id\": 0,\n        \"monetary_account_id\": 0\n      }\n    ],\n    \"counterparty_alias\": {},\n    \"description\": \"\",\n    \"merchant_reference\": \"\"\n  },\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"payment\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"allow_bunqto\": false,\n    \"amount\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"attachment\": [\n      {\n        \"id\": 0,\n        \"monetary_account_id\": 0\n      }\n    ],\n    \"counterparty_alias\": {},\n    \"description\": \"\",\n    \"merchant_reference\": \"\"\n  },\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId"

	payload := strings.NewReader("{\n  \"payment\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"allow_bunqto\": false,\n    \"amount\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"attachment\": [\n      {\n        \"id\": 0,\n        \"monetary_account_id\": 0\n      }\n    ],\n    \"counterparty_alias\": {},\n    \"description\": \"\",\n    \"merchant_reference\": \"\"\n  },\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 2897

{
  "payment": {
    "alias": {
      "avatar": {
        "anchor_uuid": "",
        "image": [
          {
            "attachment_public_uuid": "",
            "content_type": "",
            "height": 0,
            "width": 0
          }
        ],
        "style": "",
        "uuid": ""
      },
      "bunq_me": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "country": "",
      "display_name": "",
      "iban": "",
      "is_light": false,
      "label_user": {
        "avatar": {},
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "merchant_category_code": "",
      "swift_account_number": "",
      "swift_bic": "",
      "transferwise_account_number": "",
      "transferwise_bank_code": ""
    },
    "allow_bunqto": false,
    "amount": {
      "currency": "",
      "value": ""
    },
    "attachment": [
      {
        "id": 0,
        "monetary_account_id": 0
      }
    ],
    "counterparty_alias": {},
    "description": "",
    "merchant_reference": ""
  },
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  },
  "status": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"payment\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"allow_bunqto\": false,\n    \"amount\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"attachment\": [\n      {\n        \"id\": 0,\n        \"monetary_account_id\": 0\n      }\n    ],\n    \"counterparty_alias\": {},\n    \"description\": \"\",\n    \"merchant_reference\": \"\"\n  },\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"payment\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"allow_bunqto\": false,\n    \"amount\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"attachment\": [\n      {\n        \"id\": 0,\n        \"monetary_account_id\": 0\n      }\n    ],\n    \"counterparty_alias\": {},\n    \"description\": \"\",\n    \"merchant_reference\": \"\"\n  },\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"payment\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"allow_bunqto\": false,\n    \"amount\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"attachment\": [\n      {\n        \"id\": 0,\n        \"monetary_account_id\": 0\n      }\n    ],\n    \"counterparty_alias\": {},\n    \"description\": \"\",\n    \"merchant_reference\": \"\"\n  },\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"payment\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"allow_bunqto\": false,\n    \"amount\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"attachment\": [\n      {\n        \"id\": 0,\n        \"monetary_account_id\": 0\n      }\n    ],\n    \"counterparty_alias\": {},\n    \"description\": \"\",\n    \"merchant_reference\": \"\"\n  },\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  payment: {
    alias: {
      avatar: {
        anchor_uuid: '',
        image: [
          {
            attachment_public_uuid: '',
            content_type: '',
            height: 0,
            width: 0
          }
        ],
        style: '',
        uuid: ''
      },
      bunq_me: {
        name: '',
        service: '',
        type: '',
        value: ''
      },
      country: '',
      display_name: '',
      iban: '',
      is_light: false,
      label_user: {
        avatar: {},
        country: '',
        display_name: '',
        public_nick_name: '',
        uuid: ''
      },
      merchant_category_code: '',
      swift_account_number: '',
      swift_bic: '',
      transferwise_account_number: '',
      transferwise_bank_code: ''
    },
    allow_bunqto: false,
    amount: {
      currency: '',
      value: ''
    },
    attachment: [
      {
        id: 0,
        monetary_account_id: 0
      }
    ],
    counterparty_alias: {},
    description: '',
    merchant_reference: ''
  },
  schedule: {
    object: {
      Payment: {
        address_billing: {
          city: '',
          country: '',
          extra: '',
          house_number: '',
          is_user_address_updated: false,
          mailbox_name: '',
          po_box: '',
          postal_code: '',
          province: '',
          street: ''
        },
        address_shipping: {},
        alias: {},
        allow_bunqto: false,
        amount: {},
        attachment: [
          {}
        ],
        balance_after_mutation: {},
        batch_id: 0,
        bunqto_expiry: '',
        bunqto_share_url: '',
        bunqto_status: '',
        bunqto_sub_status: '',
        bunqto_time_responded: '',
        counterparty_alias: {},
        created: '',
        description: '',
        geolocation: {
          altitude: 0,
          latitude: 0,
          longitude: 0,
          radius: 0
        },
        id: 0,
        merchant_reference: '',
        monetary_account_id: 0,
        payment_auto_allocate_instance: {
          created: '',
          error_message: [],
          id: 0,
          payment_auto_allocate_id: 0,
          payment_batch: {
            payments: {
              Payment: []
            }
          },
          payment_id: 0,
          status: '',
          updated: ''
        },
        request_reference_split_the_bill: [
          {
            id: 0,
            type: ''
          }
        ],
        scheduled_id: 0,
        sub_type: '',
        type: '',
        updated: ''
      },
      PaymentBatch: {}
    },
    recurrence_size: 0,
    recurrence_unit: '',
    status: '',
    time_end: '',
    time_start: ''
  },
  status: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    payment: {
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
          style: '',
          uuid: ''
        },
        bunq_me: {name: '', service: '', type: '', value: ''},
        country: '',
        display_name: '',
        iban: '',
        is_light: false,
        label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
        merchant_category_code: '',
        swift_account_number: '',
        swift_bic: '',
        transferwise_account_number: '',
        transferwise_bank_code: ''
      },
      allow_bunqto: false,
      amount: {currency: '', value: ''},
      attachment: [{id: 0, monetary_account_id: 0}],
      counterparty_alias: {},
      description: '',
      merchant_reference: ''
    },
    schedule: {
      object: {
        Payment: {
          address_billing: {
            city: '',
            country: '',
            extra: '',
            house_number: '',
            is_user_address_updated: false,
            mailbox_name: '',
            po_box: '',
            postal_code: '',
            province: '',
            street: ''
          },
          address_shipping: {},
          alias: {},
          allow_bunqto: false,
          amount: {},
          attachment: [{}],
          balance_after_mutation: {},
          batch_id: 0,
          bunqto_expiry: '',
          bunqto_share_url: '',
          bunqto_status: '',
          bunqto_sub_status: '',
          bunqto_time_responded: '',
          counterparty_alias: {},
          created: '',
          description: '',
          geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
          id: 0,
          merchant_reference: '',
          monetary_account_id: 0,
          payment_auto_allocate_instance: {
            created: '',
            error_message: [],
            id: 0,
            payment_auto_allocate_id: 0,
            payment_batch: {payments: {Payment: []}},
            payment_id: 0,
            status: '',
            updated: ''
          },
          request_reference_split_the_bill: [{id: 0, type: ''}],
          scheduled_id: 0,
          sub_type: '',
          type: '',
          updated: ''
        },
        PaymentBatch: {}
      },
      recurrence_size: 0,
      recurrence_unit: '',
      status: '',
      time_end: '',
      time_start: ''
    },
    status: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"payment":{"alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"allow_bunqto":false,"amount":{"currency":"","value":""},"attachment":[{"id":0,"monetary_account_id":0}],"counterparty_alias":{},"description":"","merchant_reference":""},"schedule":{"object":{"Payment":{"address_billing":{"city":"","country":"","extra":"","house_number":"","is_user_address_updated":false,"mailbox_name":"","po_box":"","postal_code":"","province":"","street":""},"address_shipping":{},"alias":{},"allow_bunqto":false,"amount":{},"attachment":[{}],"balance_after_mutation":{},"batch_id":0,"bunqto_expiry":"","bunqto_share_url":"","bunqto_status":"","bunqto_sub_status":"","bunqto_time_responded":"","counterparty_alias":{},"created":"","description":"","geolocation":{"altitude":0,"latitude":0,"longitude":0,"radius":0},"id":0,"merchant_reference":"","monetary_account_id":0,"payment_auto_allocate_instance":{"created":"","error_message":[],"id":0,"payment_auto_allocate_id":0,"payment_batch":{"payments":{"Payment":[]}},"payment_id":0,"status":"","updated":""},"request_reference_split_the_bill":[{"id":0,"type":""}],"scheduled_id":0,"sub_type":"","type":"","updated":""},"PaymentBatch":{}},"recurrence_size":0,"recurrence_unit":"","status":"","time_end":"","time_start":""},"status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "payment": {\n    "alias": {\n      "avatar": {\n        "anchor_uuid": "",\n        "image": [\n          {\n            "attachment_public_uuid": "",\n            "content_type": "",\n            "height": 0,\n            "width": 0\n          }\n        ],\n        "style": "",\n        "uuid": ""\n      },\n      "bunq_me": {\n        "name": "",\n        "service": "",\n        "type": "",\n        "value": ""\n      },\n      "country": "",\n      "display_name": "",\n      "iban": "",\n      "is_light": false,\n      "label_user": {\n        "avatar": {},\n        "country": "",\n        "display_name": "",\n        "public_nick_name": "",\n        "uuid": ""\n      },\n      "merchant_category_code": "",\n      "swift_account_number": "",\n      "swift_bic": "",\n      "transferwise_account_number": "",\n      "transferwise_bank_code": ""\n    },\n    "allow_bunqto": false,\n    "amount": {\n      "currency": "",\n      "value": ""\n    },\n    "attachment": [\n      {\n        "id": 0,\n        "monetary_account_id": 0\n      }\n    ],\n    "counterparty_alias": {},\n    "description": "",\n    "merchant_reference": ""\n  },\n  "schedule": {\n    "object": {\n      "Payment": {\n        "address_billing": {\n          "city": "",\n          "country": "",\n          "extra": "",\n          "house_number": "",\n          "is_user_address_updated": false,\n          "mailbox_name": "",\n          "po_box": "",\n          "postal_code": "",\n          "province": "",\n          "street": ""\n        },\n        "address_shipping": {},\n        "alias": {},\n        "allow_bunqto": false,\n        "amount": {},\n        "attachment": [\n          {}\n        ],\n        "balance_after_mutation": {},\n        "batch_id": 0,\n        "bunqto_expiry": "",\n        "bunqto_share_url": "",\n        "bunqto_status": "",\n        "bunqto_sub_status": "",\n        "bunqto_time_responded": "",\n        "counterparty_alias": {},\n        "created": "",\n        "description": "",\n        "geolocation": {\n          "altitude": 0,\n          "latitude": 0,\n          "longitude": 0,\n          "radius": 0\n        },\n        "id": 0,\n        "merchant_reference": "",\n        "monetary_account_id": 0,\n        "payment_auto_allocate_instance": {\n          "created": "",\n          "error_message": [],\n          "id": 0,\n          "payment_auto_allocate_id": 0,\n          "payment_batch": {\n            "payments": {\n              "Payment": []\n            }\n          },\n          "payment_id": 0,\n          "status": "",\n          "updated": ""\n        },\n        "request_reference_split_the_bill": [\n          {\n            "id": 0,\n            "type": ""\n          }\n        ],\n        "scheduled_id": 0,\n        "sub_type": "",\n        "type": "",\n        "updated": ""\n      },\n      "PaymentBatch": {}\n    },\n    "recurrence_size": 0,\n    "recurrence_unit": "",\n    "status": "",\n    "time_end": "",\n    "time_start": ""\n  },\n  "status": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"payment\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"allow_bunqto\": false,\n    \"amount\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"attachment\": [\n      {\n        \"id\": 0,\n        \"monetary_account_id\": 0\n      }\n    ],\n    \"counterparty_alias\": {},\n    \"description\": \"\",\n    \"merchant_reference\": \"\"\n  },\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  payment: {
    alias: {
      avatar: {
        anchor_uuid: '',
        image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
        style: '',
        uuid: ''
      },
      bunq_me: {name: '', service: '', type: '', value: ''},
      country: '',
      display_name: '',
      iban: '',
      is_light: false,
      label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
      merchant_category_code: '',
      swift_account_number: '',
      swift_bic: '',
      transferwise_account_number: '',
      transferwise_bank_code: ''
    },
    allow_bunqto: false,
    amount: {currency: '', value: ''},
    attachment: [{id: 0, monetary_account_id: 0}],
    counterparty_alias: {},
    description: '',
    merchant_reference: ''
  },
  schedule: {
    object: {
      Payment: {
        address_billing: {
          city: '',
          country: '',
          extra: '',
          house_number: '',
          is_user_address_updated: false,
          mailbox_name: '',
          po_box: '',
          postal_code: '',
          province: '',
          street: ''
        },
        address_shipping: {},
        alias: {},
        allow_bunqto: false,
        amount: {},
        attachment: [{}],
        balance_after_mutation: {},
        batch_id: 0,
        bunqto_expiry: '',
        bunqto_share_url: '',
        bunqto_status: '',
        bunqto_sub_status: '',
        bunqto_time_responded: '',
        counterparty_alias: {},
        created: '',
        description: '',
        geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
        id: 0,
        merchant_reference: '',
        monetary_account_id: 0,
        payment_auto_allocate_instance: {
          created: '',
          error_message: [],
          id: 0,
          payment_auto_allocate_id: 0,
          payment_batch: {payments: {Payment: []}},
          payment_id: 0,
          status: '',
          updated: ''
        },
        request_reference_split_the_bill: [{id: 0, type: ''}],
        scheduled_id: 0,
        sub_type: '',
        type: '',
        updated: ''
      },
      PaymentBatch: {}
    },
    recurrence_size: 0,
    recurrence_unit: '',
    status: '',
    time_end: '',
    time_start: ''
  },
  status: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    payment: {
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
          style: '',
          uuid: ''
        },
        bunq_me: {name: '', service: '', type: '', value: ''},
        country: '',
        display_name: '',
        iban: '',
        is_light: false,
        label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
        merchant_category_code: '',
        swift_account_number: '',
        swift_bic: '',
        transferwise_account_number: '',
        transferwise_bank_code: ''
      },
      allow_bunqto: false,
      amount: {currency: '', value: ''},
      attachment: [{id: 0, monetary_account_id: 0}],
      counterparty_alias: {},
      description: '',
      merchant_reference: ''
    },
    schedule: {
      object: {
        Payment: {
          address_billing: {
            city: '',
            country: '',
            extra: '',
            house_number: '',
            is_user_address_updated: false,
            mailbox_name: '',
            po_box: '',
            postal_code: '',
            province: '',
            street: ''
          },
          address_shipping: {},
          alias: {},
          allow_bunqto: false,
          amount: {},
          attachment: [{}],
          balance_after_mutation: {},
          batch_id: 0,
          bunqto_expiry: '',
          bunqto_share_url: '',
          bunqto_status: '',
          bunqto_sub_status: '',
          bunqto_time_responded: '',
          counterparty_alias: {},
          created: '',
          description: '',
          geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
          id: 0,
          merchant_reference: '',
          monetary_account_id: 0,
          payment_auto_allocate_instance: {
            created: '',
            error_message: [],
            id: 0,
            payment_auto_allocate_id: 0,
            payment_batch: {payments: {Payment: []}},
            payment_id: 0,
            status: '',
            updated: ''
          },
          request_reference_split_the_bill: [{id: 0, type: ''}],
          scheduled_id: 0,
          sub_type: '',
          type: '',
          updated: ''
        },
        PaymentBatch: {}
      },
      recurrence_size: 0,
      recurrence_unit: '',
      status: '',
      time_end: '',
      time_start: ''
    },
    status: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  payment: {
    alias: {
      avatar: {
        anchor_uuid: '',
        image: [
          {
            attachment_public_uuid: '',
            content_type: '',
            height: 0,
            width: 0
          }
        ],
        style: '',
        uuid: ''
      },
      bunq_me: {
        name: '',
        service: '',
        type: '',
        value: ''
      },
      country: '',
      display_name: '',
      iban: '',
      is_light: false,
      label_user: {
        avatar: {},
        country: '',
        display_name: '',
        public_nick_name: '',
        uuid: ''
      },
      merchant_category_code: '',
      swift_account_number: '',
      swift_bic: '',
      transferwise_account_number: '',
      transferwise_bank_code: ''
    },
    allow_bunqto: false,
    amount: {
      currency: '',
      value: ''
    },
    attachment: [
      {
        id: 0,
        monetary_account_id: 0
      }
    ],
    counterparty_alias: {},
    description: '',
    merchant_reference: ''
  },
  schedule: {
    object: {
      Payment: {
        address_billing: {
          city: '',
          country: '',
          extra: '',
          house_number: '',
          is_user_address_updated: false,
          mailbox_name: '',
          po_box: '',
          postal_code: '',
          province: '',
          street: ''
        },
        address_shipping: {},
        alias: {},
        allow_bunqto: false,
        amount: {},
        attachment: [
          {}
        ],
        balance_after_mutation: {},
        batch_id: 0,
        bunqto_expiry: '',
        bunqto_share_url: '',
        bunqto_status: '',
        bunqto_sub_status: '',
        bunqto_time_responded: '',
        counterparty_alias: {},
        created: '',
        description: '',
        geolocation: {
          altitude: 0,
          latitude: 0,
          longitude: 0,
          radius: 0
        },
        id: 0,
        merchant_reference: '',
        monetary_account_id: 0,
        payment_auto_allocate_instance: {
          created: '',
          error_message: [],
          id: 0,
          payment_auto_allocate_id: 0,
          payment_batch: {
            payments: {
              Payment: []
            }
          },
          payment_id: 0,
          status: '',
          updated: ''
        },
        request_reference_split_the_bill: [
          {
            id: 0,
            type: ''
          }
        ],
        scheduled_id: 0,
        sub_type: '',
        type: '',
        updated: ''
      },
      PaymentBatch: {}
    },
    recurrence_size: 0,
    recurrence_unit: '',
    status: '',
    time_end: '',
    time_start: ''
  },
  status: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    payment: {
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
          style: '',
          uuid: ''
        },
        bunq_me: {name: '', service: '', type: '', value: ''},
        country: '',
        display_name: '',
        iban: '',
        is_light: false,
        label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
        merchant_category_code: '',
        swift_account_number: '',
        swift_bic: '',
        transferwise_account_number: '',
        transferwise_bank_code: ''
      },
      allow_bunqto: false,
      amount: {currency: '', value: ''},
      attachment: [{id: 0, monetary_account_id: 0}],
      counterparty_alias: {},
      description: '',
      merchant_reference: ''
    },
    schedule: {
      object: {
        Payment: {
          address_billing: {
            city: '',
            country: '',
            extra: '',
            house_number: '',
            is_user_address_updated: false,
            mailbox_name: '',
            po_box: '',
            postal_code: '',
            province: '',
            street: ''
          },
          address_shipping: {},
          alias: {},
          allow_bunqto: false,
          amount: {},
          attachment: [{}],
          balance_after_mutation: {},
          batch_id: 0,
          bunqto_expiry: '',
          bunqto_share_url: '',
          bunqto_status: '',
          bunqto_sub_status: '',
          bunqto_time_responded: '',
          counterparty_alias: {},
          created: '',
          description: '',
          geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
          id: 0,
          merchant_reference: '',
          monetary_account_id: 0,
          payment_auto_allocate_instance: {
            created: '',
            error_message: [],
            id: 0,
            payment_auto_allocate_id: 0,
            payment_batch: {payments: {Payment: []}},
            payment_id: 0,
            status: '',
            updated: ''
          },
          request_reference_split_the_bill: [{id: 0, type: ''}],
          scheduled_id: 0,
          sub_type: '',
          type: '',
          updated: ''
        },
        PaymentBatch: {}
      },
      recurrence_size: 0,
      recurrence_unit: '',
      status: '',
      time_end: '',
      time_start: ''
    },
    status: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"payment":{"alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"allow_bunqto":false,"amount":{"currency":"","value":""},"attachment":[{"id":0,"monetary_account_id":0}],"counterparty_alias":{},"description":"","merchant_reference":""},"schedule":{"object":{"Payment":{"address_billing":{"city":"","country":"","extra":"","house_number":"","is_user_address_updated":false,"mailbox_name":"","po_box":"","postal_code":"","province":"","street":""},"address_shipping":{},"alias":{},"allow_bunqto":false,"amount":{},"attachment":[{}],"balance_after_mutation":{},"batch_id":0,"bunqto_expiry":"","bunqto_share_url":"","bunqto_status":"","bunqto_sub_status":"","bunqto_time_responded":"","counterparty_alias":{},"created":"","description":"","geolocation":{"altitude":0,"latitude":0,"longitude":0,"radius":0},"id":0,"merchant_reference":"","monetary_account_id":0,"payment_auto_allocate_instance":{"created":"","error_message":[],"id":0,"payment_auto_allocate_id":0,"payment_batch":{"payments":{"Payment":[]}},"payment_id":0,"status":"","updated":""},"request_reference_split_the_bill":[{"id":0,"type":""}],"scheduled_id":0,"sub_type":"","type":"","updated":""},"PaymentBatch":{}},"recurrence_size":0,"recurrence_unit":"","status":"","time_end":"","time_start":""},"status":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"payment": @{ @"alias": @{ @"avatar": @{ @"anchor_uuid": @"", @"image": @[ @{ @"attachment_public_uuid": @"", @"content_type": @"", @"height": @0, @"width": @0 } ], @"style": @"", @"uuid": @"" }, @"bunq_me": @{ @"name": @"", @"service": @"", @"type": @"", @"value": @"" }, @"country": @"", @"display_name": @"", @"iban": @"", @"is_light": @NO, @"label_user": @{ @"avatar": @{  }, @"country": @"", @"display_name": @"", @"public_nick_name": @"", @"uuid": @"" }, @"merchant_category_code": @"", @"swift_account_number": @"", @"swift_bic": @"", @"transferwise_account_number": @"", @"transferwise_bank_code": @"" }, @"allow_bunqto": @NO, @"amount": @{ @"currency": @"", @"value": @"" }, @"attachment": @[ @{ @"id": @0, @"monetary_account_id": @0 } ], @"counterparty_alias": @{  }, @"description": @"", @"merchant_reference": @"" },
                              @"schedule": @{ @"object": @{ @"Payment": @{ @"address_billing": @{ @"city": @"", @"country": @"", @"extra": @"", @"house_number": @"", @"is_user_address_updated": @NO, @"mailbox_name": @"", @"po_box": @"", @"postal_code": @"", @"province": @"", @"street": @"" }, @"address_shipping": @{  }, @"alias": @{  }, @"allow_bunqto": @NO, @"amount": @{  }, @"attachment": @[ @{  } ], @"balance_after_mutation": @{  }, @"batch_id": @0, @"bunqto_expiry": @"", @"bunqto_share_url": @"", @"bunqto_status": @"", @"bunqto_sub_status": @"", @"bunqto_time_responded": @"", @"counterparty_alias": @{  }, @"created": @"", @"description": @"", @"geolocation": @{ @"altitude": @0, @"latitude": @0, @"longitude": @0, @"radius": @0 }, @"id": @0, @"merchant_reference": @"", @"monetary_account_id": @0, @"payment_auto_allocate_instance": @{ @"created": @"", @"error_message": @[  ], @"id": @0, @"payment_auto_allocate_id": @0, @"payment_batch": @{ @"payments": @{ @"Payment": @[  ] } }, @"payment_id": @0, @"status": @"", @"updated": @"" }, @"request_reference_split_the_bill": @[ @{ @"id": @0, @"type": @"" } ], @"scheduled_id": @0, @"sub_type": @"", @"type": @"", @"updated": @"" }, @"PaymentBatch": @{  } }, @"recurrence_size": @0, @"recurrence_unit": @"", @"status": @"", @"time_end": @"", @"time_start": @"" },
                              @"status": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"payment\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"allow_bunqto\": false,\n    \"amount\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"attachment\": [\n      {\n        \"id\": 0,\n        \"monetary_account_id\": 0\n      }\n    ],\n    \"counterparty_alias\": {},\n    \"description\": \"\",\n    \"merchant_reference\": \"\"\n  },\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'payment' => [
        'alias' => [
                'avatar' => [
                                'anchor_uuid' => '',
                                'image' => [
                                                                [
                                                                                                                                'attachment_public_uuid' => '',
                                                                                                                                'content_type' => '',
                                                                                                                                'height' => 0,
                                                                                                                                'width' => 0
                                                                ]
                                ],
                                'style' => '',
                                'uuid' => ''
                ],
                'bunq_me' => [
                                'name' => '',
                                'service' => '',
                                'type' => '',
                                'value' => ''
                ],
                'country' => '',
                'display_name' => '',
                'iban' => '',
                'is_light' => null,
                'label_user' => [
                                'avatar' => [
                                                                
                                ],
                                'country' => '',
                                'display_name' => '',
                                'public_nick_name' => '',
                                'uuid' => ''
                ],
                'merchant_category_code' => '',
                'swift_account_number' => '',
                'swift_bic' => '',
                'transferwise_account_number' => '',
                'transferwise_bank_code' => ''
        ],
        'allow_bunqto' => null,
        'amount' => [
                'currency' => '',
                'value' => ''
        ],
        'attachment' => [
                [
                                'id' => 0,
                                'monetary_account_id' => 0
                ]
        ],
        'counterparty_alias' => [
                
        ],
        'description' => '',
        'merchant_reference' => ''
    ],
    'schedule' => [
        'object' => [
                'Payment' => [
                                'address_billing' => [
                                                                'city' => '',
                                                                'country' => '',
                                                                'extra' => '',
                                                                'house_number' => '',
                                                                'is_user_address_updated' => null,
                                                                'mailbox_name' => '',
                                                                'po_box' => '',
                                                                'postal_code' => '',
                                                                'province' => '',
                                                                'street' => ''
                                ],
                                'address_shipping' => [
                                                                
                                ],
                                'alias' => [
                                                                
                                ],
                                'allow_bunqto' => null,
                                'amount' => [
                                                                
                                ],
                                'attachment' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'balance_after_mutation' => [
                                                                
                                ],
                                'batch_id' => 0,
                                'bunqto_expiry' => '',
                                'bunqto_share_url' => '',
                                'bunqto_status' => '',
                                'bunqto_sub_status' => '',
                                'bunqto_time_responded' => '',
                                'counterparty_alias' => [
                                                                
                                ],
                                'created' => '',
                                'description' => '',
                                'geolocation' => [
                                                                'altitude' => 0,
                                                                'latitude' => 0,
                                                                'longitude' => 0,
                                                                'radius' => 0
                                ],
                                'id' => 0,
                                'merchant_reference' => '',
                                'monetary_account_id' => 0,
                                'payment_auto_allocate_instance' => [
                                                                'created' => '',
                                                                'error_message' => [
                                                                                                                                
                                                                ],
                                                                'id' => 0,
                                                                'payment_auto_allocate_id' => 0,
                                                                'payment_batch' => [
                                                                                                                                'payments' => [
                                                                                                                                                                                                                                                                'Payment' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ]
                                                                                                                                ]
                                                                ],
                                                                'payment_id' => 0,
                                                                'status' => '',
                                                                'updated' => ''
                                ],
                                'request_reference_split_the_bill' => [
                                                                [
                                                                                                                                'id' => 0,
                                                                                                                                'type' => ''
                                                                ]
                                ],
                                'scheduled_id' => 0,
                                'sub_type' => '',
                                'type' => '',
                                'updated' => ''
                ],
                'PaymentBatch' => [
                                
                ]
        ],
        'recurrence_size' => 0,
        'recurrence_unit' => '',
        'status' => '',
        'time_end' => '',
        'time_start' => ''
    ],
    'status' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId', [
  'body' => '{
  "payment": {
    "alias": {
      "avatar": {
        "anchor_uuid": "",
        "image": [
          {
            "attachment_public_uuid": "",
            "content_type": "",
            "height": 0,
            "width": 0
          }
        ],
        "style": "",
        "uuid": ""
      },
      "bunq_me": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "country": "",
      "display_name": "",
      "iban": "",
      "is_light": false,
      "label_user": {
        "avatar": {},
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "merchant_category_code": "",
      "swift_account_number": "",
      "swift_bic": "",
      "transferwise_account_number": "",
      "transferwise_bank_code": ""
    },
    "allow_bunqto": false,
    "amount": {
      "currency": "",
      "value": ""
    },
    "attachment": [
      {
        "id": 0,
        "monetary_account_id": 0
      }
    ],
    "counterparty_alias": {},
    "description": "",
    "merchant_reference": ""
  },
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  },
  "status": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'payment' => [
    'alias' => [
        'avatar' => [
                'anchor_uuid' => '',
                'image' => [
                                [
                                                                'attachment_public_uuid' => '',
                                                                'content_type' => '',
                                                                'height' => 0,
                                                                'width' => 0
                                ]
                ],
                'style' => '',
                'uuid' => ''
        ],
        'bunq_me' => [
                'name' => '',
                'service' => '',
                'type' => '',
                'value' => ''
        ],
        'country' => '',
        'display_name' => '',
        'iban' => '',
        'is_light' => null,
        'label_user' => [
                'avatar' => [
                                
                ],
                'country' => '',
                'display_name' => '',
                'public_nick_name' => '',
                'uuid' => ''
        ],
        'merchant_category_code' => '',
        'swift_account_number' => '',
        'swift_bic' => '',
        'transferwise_account_number' => '',
        'transferwise_bank_code' => ''
    ],
    'allow_bunqto' => null,
    'amount' => [
        'currency' => '',
        'value' => ''
    ],
    'attachment' => [
        [
                'id' => 0,
                'monetary_account_id' => 0
        ]
    ],
    'counterparty_alias' => [
        
    ],
    'description' => '',
    'merchant_reference' => ''
  ],
  'schedule' => [
    'object' => [
        'Payment' => [
                'address_billing' => [
                                'city' => '',
                                'country' => '',
                                'extra' => '',
                                'house_number' => '',
                                'is_user_address_updated' => null,
                                'mailbox_name' => '',
                                'po_box' => '',
                                'postal_code' => '',
                                'province' => '',
                                'street' => ''
                ],
                'address_shipping' => [
                                
                ],
                'alias' => [
                                
                ],
                'allow_bunqto' => null,
                'amount' => [
                                
                ],
                'attachment' => [
                                [
                                                                
                                ]
                ],
                'balance_after_mutation' => [
                                
                ],
                'batch_id' => 0,
                'bunqto_expiry' => '',
                'bunqto_share_url' => '',
                'bunqto_status' => '',
                'bunqto_sub_status' => '',
                'bunqto_time_responded' => '',
                'counterparty_alias' => [
                                
                ],
                'created' => '',
                'description' => '',
                'geolocation' => [
                                'altitude' => 0,
                                'latitude' => 0,
                                'longitude' => 0,
                                'radius' => 0
                ],
                'id' => 0,
                'merchant_reference' => '',
                'monetary_account_id' => 0,
                'payment_auto_allocate_instance' => [
                                'created' => '',
                                'error_message' => [
                                                                
                                ],
                                'id' => 0,
                                'payment_auto_allocate_id' => 0,
                                'payment_batch' => [
                                                                'payments' => [
                                                                                                                                'Payment' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'payment_id' => 0,
                                'status' => '',
                                'updated' => ''
                ],
                'request_reference_split_the_bill' => [
                                [
                                                                'id' => 0,
                                                                'type' => ''
                                ]
                ],
                'scheduled_id' => 0,
                'sub_type' => '',
                'type' => '',
                'updated' => ''
        ],
        'PaymentBatch' => [
                
        ]
    ],
    'recurrence_size' => 0,
    'recurrence_unit' => '',
    'status' => '',
    'time_end' => '',
    'time_start' => ''
  ],
  'status' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'payment' => [
    'alias' => [
        'avatar' => [
                'anchor_uuid' => '',
                'image' => [
                                [
                                                                'attachment_public_uuid' => '',
                                                                'content_type' => '',
                                                                'height' => 0,
                                                                'width' => 0
                                ]
                ],
                'style' => '',
                'uuid' => ''
        ],
        'bunq_me' => [
                'name' => '',
                'service' => '',
                'type' => '',
                'value' => ''
        ],
        'country' => '',
        'display_name' => '',
        'iban' => '',
        'is_light' => null,
        'label_user' => [
                'avatar' => [
                                
                ],
                'country' => '',
                'display_name' => '',
                'public_nick_name' => '',
                'uuid' => ''
        ],
        'merchant_category_code' => '',
        'swift_account_number' => '',
        'swift_bic' => '',
        'transferwise_account_number' => '',
        'transferwise_bank_code' => ''
    ],
    'allow_bunqto' => null,
    'amount' => [
        'currency' => '',
        'value' => ''
    ],
    'attachment' => [
        [
                'id' => 0,
                'monetary_account_id' => 0
        ]
    ],
    'counterparty_alias' => [
        
    ],
    'description' => '',
    'merchant_reference' => ''
  ],
  'schedule' => [
    'object' => [
        'Payment' => [
                'address_billing' => [
                                'city' => '',
                                'country' => '',
                                'extra' => '',
                                'house_number' => '',
                                'is_user_address_updated' => null,
                                'mailbox_name' => '',
                                'po_box' => '',
                                'postal_code' => '',
                                'province' => '',
                                'street' => ''
                ],
                'address_shipping' => [
                                
                ],
                'alias' => [
                                
                ],
                'allow_bunqto' => null,
                'amount' => [
                                
                ],
                'attachment' => [
                                [
                                                                
                                ]
                ],
                'balance_after_mutation' => [
                                
                ],
                'batch_id' => 0,
                'bunqto_expiry' => '',
                'bunqto_share_url' => '',
                'bunqto_status' => '',
                'bunqto_sub_status' => '',
                'bunqto_time_responded' => '',
                'counterparty_alias' => [
                                
                ],
                'created' => '',
                'description' => '',
                'geolocation' => [
                                'altitude' => 0,
                                'latitude' => 0,
                                'longitude' => 0,
                                'radius' => 0
                ],
                'id' => 0,
                'merchant_reference' => '',
                'monetary_account_id' => 0,
                'payment_auto_allocate_instance' => [
                                'created' => '',
                                'error_message' => [
                                                                
                                ],
                                'id' => 0,
                                'payment_auto_allocate_id' => 0,
                                'payment_batch' => [
                                                                'payments' => [
                                                                                                                                'Payment' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'payment_id' => 0,
                                'status' => '',
                                'updated' => ''
                ],
                'request_reference_split_the_bill' => [
                                [
                                                                'id' => 0,
                                                                'type' => ''
                                ]
                ],
                'scheduled_id' => 0,
                'sub_type' => '',
                'type' => '',
                'updated' => ''
        ],
        'PaymentBatch' => [
                
        ]
    ],
    'recurrence_size' => 0,
    'recurrence_unit' => '',
    'status' => '',
    'time_end' => '',
    'time_start' => ''
  ],
  'status' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "payment": {
    "alias": {
      "avatar": {
        "anchor_uuid": "",
        "image": [
          {
            "attachment_public_uuid": "",
            "content_type": "",
            "height": 0,
            "width": 0
          }
        ],
        "style": "",
        "uuid": ""
      },
      "bunq_me": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "country": "",
      "display_name": "",
      "iban": "",
      "is_light": false,
      "label_user": {
        "avatar": {},
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "merchant_category_code": "",
      "swift_account_number": "",
      "swift_bic": "",
      "transferwise_account_number": "",
      "transferwise_bank_code": ""
    },
    "allow_bunqto": false,
    "amount": {
      "currency": "",
      "value": ""
    },
    "attachment": [
      {
        "id": 0,
        "monetary_account_id": 0
      }
    ],
    "counterparty_alias": {},
    "description": "",
    "merchant_reference": ""
  },
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  },
  "status": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "payment": {
    "alias": {
      "avatar": {
        "anchor_uuid": "",
        "image": [
          {
            "attachment_public_uuid": "",
            "content_type": "",
            "height": 0,
            "width": 0
          }
        ],
        "style": "",
        "uuid": ""
      },
      "bunq_me": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "country": "",
      "display_name": "",
      "iban": "",
      "is_light": false,
      "label_user": {
        "avatar": {},
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "merchant_category_code": "",
      "swift_account_number": "",
      "swift_bic": "",
      "transferwise_account_number": "",
      "transferwise_bank_code": ""
    },
    "allow_bunqto": false,
    "amount": {
      "currency": "",
      "value": ""
    },
    "attachment": [
      {
        "id": 0,
        "monetary_account_id": 0
      }
    ],
    "counterparty_alias": {},
    "description": "",
    "merchant_reference": ""
  },
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  },
  "status": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"payment\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"allow_bunqto\": false,\n    \"amount\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"attachment\": [\n      {\n        \"id\": 0,\n        \"monetary_account_id\": 0\n      }\n    ],\n    \"counterparty_alias\": {},\n    \"description\": \"\",\n    \"merchant_reference\": \"\"\n  },\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId"

payload = {
    "payment": {
        "alias": {
            "avatar": {
                "anchor_uuid": "",
                "image": [
                    {
                        "attachment_public_uuid": "",
                        "content_type": "",
                        "height": 0,
                        "width": 0
                    }
                ],
                "style": "",
                "uuid": ""
            },
            "bunq_me": {
                "name": "",
                "service": "",
                "type": "",
                "value": ""
            },
            "country": "",
            "display_name": "",
            "iban": "",
            "is_light": False,
            "label_user": {
                "avatar": {},
                "country": "",
                "display_name": "",
                "public_nick_name": "",
                "uuid": ""
            },
            "merchant_category_code": "",
            "swift_account_number": "",
            "swift_bic": "",
            "transferwise_account_number": "",
            "transferwise_bank_code": ""
        },
        "allow_bunqto": False,
        "amount": {
            "currency": "",
            "value": ""
        },
        "attachment": [
            {
                "id": 0,
                "monetary_account_id": 0
            }
        ],
        "counterparty_alias": {},
        "description": "",
        "merchant_reference": ""
    },
    "schedule": {
        "object": {
            "Payment": {
                "address_billing": {
                    "city": "",
                    "country": "",
                    "extra": "",
                    "house_number": "",
                    "is_user_address_updated": False,
                    "mailbox_name": "",
                    "po_box": "",
                    "postal_code": "",
                    "province": "",
                    "street": ""
                },
                "address_shipping": {},
                "alias": {},
                "allow_bunqto": False,
                "amount": {},
                "attachment": [{}],
                "balance_after_mutation": {},
                "batch_id": 0,
                "bunqto_expiry": "",
                "bunqto_share_url": "",
                "bunqto_status": "",
                "bunqto_sub_status": "",
                "bunqto_time_responded": "",
                "counterparty_alias": {},
                "created": "",
                "description": "",
                "geolocation": {
                    "altitude": 0,
                    "latitude": 0,
                    "longitude": 0,
                    "radius": 0
                },
                "id": 0,
                "merchant_reference": "",
                "monetary_account_id": 0,
                "payment_auto_allocate_instance": {
                    "created": "",
                    "error_message": [],
                    "id": 0,
                    "payment_auto_allocate_id": 0,
                    "payment_batch": { "payments": { "Payment": [] } },
                    "payment_id": 0,
                    "status": "",
                    "updated": ""
                },
                "request_reference_split_the_bill": [
                    {
                        "id": 0,
                        "type": ""
                    }
                ],
                "scheduled_id": 0,
                "sub_type": "",
                "type": "",
                "updated": ""
            },
            "PaymentBatch": {}
        },
        "recurrence_size": 0,
        "recurrence_unit": "",
        "status": "",
        "time_end": "",
        "time_start": ""
    },
    "status": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId"

payload <- "{\n  \"payment\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"allow_bunqto\": false,\n    \"amount\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"attachment\": [\n      {\n        \"id\": 0,\n        \"monetary_account_id\": 0\n      }\n    ],\n    \"counterparty_alias\": {},\n    \"description\": \"\",\n    \"merchant_reference\": \"\"\n  },\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"payment\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"allow_bunqto\": false,\n    \"amount\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"attachment\": [\n      {\n        \"id\": 0,\n        \"monetary_account_id\": 0\n      }\n    ],\n    \"counterparty_alias\": {},\n    \"description\": \"\",\n    \"merchant_reference\": \"\"\n  },\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"payment\": {\n    \"alias\": {\n      \"avatar\": {\n        \"anchor_uuid\": \"\",\n        \"image\": [\n          {\n            \"attachment_public_uuid\": \"\",\n            \"content_type\": \"\",\n            \"height\": 0,\n            \"width\": 0\n          }\n        ],\n        \"style\": \"\",\n        \"uuid\": \"\"\n      },\n      \"bunq_me\": {\n        \"name\": \"\",\n        \"service\": \"\",\n        \"type\": \"\",\n        \"value\": \"\"\n      },\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"iban\": \"\",\n      \"is_light\": false,\n      \"label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"merchant_category_code\": \"\",\n      \"swift_account_number\": \"\",\n      \"swift_bic\": \"\",\n      \"transferwise_account_number\": \"\",\n      \"transferwise_bank_code\": \"\"\n    },\n    \"allow_bunqto\": false,\n    \"amount\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"attachment\": [\n      {\n        \"id\": 0,\n        \"monetary_account_id\": 0\n      }\n    ],\n    \"counterparty_alias\": {},\n    \"description\": \"\",\n    \"merchant_reference\": \"\"\n  },\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  },\n  \"status\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId";

    let payload = json!({
        "payment": json!({
            "alias": json!({
                "avatar": json!({
                    "anchor_uuid": "",
                    "image": (
                        json!({
                            "attachment_public_uuid": "",
                            "content_type": "",
                            "height": 0,
                            "width": 0
                        })
                    ),
                    "style": "",
                    "uuid": ""
                }),
                "bunq_me": json!({
                    "name": "",
                    "service": "",
                    "type": "",
                    "value": ""
                }),
                "country": "",
                "display_name": "",
                "iban": "",
                "is_light": false,
                "label_user": json!({
                    "avatar": json!({}),
                    "country": "",
                    "display_name": "",
                    "public_nick_name": "",
                    "uuid": ""
                }),
                "merchant_category_code": "",
                "swift_account_number": "",
                "swift_bic": "",
                "transferwise_account_number": "",
                "transferwise_bank_code": ""
            }),
            "allow_bunqto": false,
            "amount": json!({
                "currency": "",
                "value": ""
            }),
            "attachment": (
                json!({
                    "id": 0,
                    "monetary_account_id": 0
                })
            ),
            "counterparty_alias": json!({}),
            "description": "",
            "merchant_reference": ""
        }),
        "schedule": json!({
            "object": json!({
                "Payment": json!({
                    "address_billing": json!({
                        "city": "",
                        "country": "",
                        "extra": "",
                        "house_number": "",
                        "is_user_address_updated": false,
                        "mailbox_name": "",
                        "po_box": "",
                        "postal_code": "",
                        "province": "",
                        "street": ""
                    }),
                    "address_shipping": json!({}),
                    "alias": json!({}),
                    "allow_bunqto": false,
                    "amount": json!({}),
                    "attachment": (json!({})),
                    "balance_after_mutation": json!({}),
                    "batch_id": 0,
                    "bunqto_expiry": "",
                    "bunqto_share_url": "",
                    "bunqto_status": "",
                    "bunqto_sub_status": "",
                    "bunqto_time_responded": "",
                    "counterparty_alias": json!({}),
                    "created": "",
                    "description": "",
                    "geolocation": json!({
                        "altitude": 0,
                        "latitude": 0,
                        "longitude": 0,
                        "radius": 0
                    }),
                    "id": 0,
                    "merchant_reference": "",
                    "monetary_account_id": 0,
                    "payment_auto_allocate_instance": json!({
                        "created": "",
                        "error_message": (),
                        "id": 0,
                        "payment_auto_allocate_id": 0,
                        "payment_batch": json!({"payments": json!({"Payment": ()})}),
                        "payment_id": 0,
                        "status": "",
                        "updated": ""
                    }),
                    "request_reference_split_the_bill": (
                        json!({
                            "id": 0,
                            "type": ""
                        })
                    ),
                    "scheduled_id": 0,
                    "sub_type": "",
                    "type": "",
                    "updated": ""
                }),
                "PaymentBatch": json!({})
            }),
            "recurrence_size": 0,
            "recurrence_unit": "",
            "status": "",
            "time_end": "",
            "time_start": ""
        }),
        "status": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "payment": {
    "alias": {
      "avatar": {
        "anchor_uuid": "",
        "image": [
          {
            "attachment_public_uuid": "",
            "content_type": "",
            "height": 0,
            "width": 0
          }
        ],
        "style": "",
        "uuid": ""
      },
      "bunq_me": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "country": "",
      "display_name": "",
      "iban": "",
      "is_light": false,
      "label_user": {
        "avatar": {},
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "merchant_category_code": "",
      "swift_account_number": "",
      "swift_bic": "",
      "transferwise_account_number": "",
      "transferwise_bank_code": ""
    },
    "allow_bunqto": false,
    "amount": {
      "currency": "",
      "value": ""
    },
    "attachment": [
      {
        "id": 0,
        "monetary_account_id": 0
      }
    ],
    "counterparty_alias": {},
    "description": "",
    "merchant_reference": ""
  },
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  },
  "status": ""
}'
echo '{
  "payment": {
    "alias": {
      "avatar": {
        "anchor_uuid": "",
        "image": [
          {
            "attachment_public_uuid": "",
            "content_type": "",
            "height": 0,
            "width": 0
          }
        ],
        "style": "",
        "uuid": ""
      },
      "bunq_me": {
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      },
      "country": "",
      "display_name": "",
      "iban": "",
      "is_light": false,
      "label_user": {
        "avatar": {},
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "merchant_category_code": "",
      "swift_account_number": "",
      "swift_bic": "",
      "transferwise_account_number": "",
      "transferwise_bank_code": ""
    },
    "allow_bunqto": false,
    "amount": {
      "currency": "",
      "value": ""
    },
    "attachment": [
      {
        "id": 0,
        "monetary_account_id": 0
      }
    ],
    "counterparty_alias": {},
    "description": "",
    "merchant_reference": ""
  },
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  },
  "status": ""
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "payment": {\n    "alias": {\n      "avatar": {\n        "anchor_uuid": "",\n        "image": [\n          {\n            "attachment_public_uuid": "",\n            "content_type": "",\n            "height": 0,\n            "width": 0\n          }\n        ],\n        "style": "",\n        "uuid": ""\n      },\n      "bunq_me": {\n        "name": "",\n        "service": "",\n        "type": "",\n        "value": ""\n      },\n      "country": "",\n      "display_name": "",\n      "iban": "",\n      "is_light": false,\n      "label_user": {\n        "avatar": {},\n        "country": "",\n        "display_name": "",\n        "public_nick_name": "",\n        "uuid": ""\n      },\n      "merchant_category_code": "",\n      "swift_account_number": "",\n      "swift_bic": "",\n      "transferwise_account_number": "",\n      "transferwise_bank_code": ""\n    },\n    "allow_bunqto": false,\n    "amount": {\n      "currency": "",\n      "value": ""\n    },\n    "attachment": [\n      {\n        "id": 0,\n        "monetary_account_id": 0\n      }\n    ],\n    "counterparty_alias": {},\n    "description": "",\n    "merchant_reference": ""\n  },\n  "schedule": {\n    "object": {\n      "Payment": {\n        "address_billing": {\n          "city": "",\n          "country": "",\n          "extra": "",\n          "house_number": "",\n          "is_user_address_updated": false,\n          "mailbox_name": "",\n          "po_box": "",\n          "postal_code": "",\n          "province": "",\n          "street": ""\n        },\n        "address_shipping": {},\n        "alias": {},\n        "allow_bunqto": false,\n        "amount": {},\n        "attachment": [\n          {}\n        ],\n        "balance_after_mutation": {},\n        "batch_id": 0,\n        "bunqto_expiry": "",\n        "bunqto_share_url": "",\n        "bunqto_status": "",\n        "bunqto_sub_status": "",\n        "bunqto_time_responded": "",\n        "counterparty_alias": {},\n        "created": "",\n        "description": "",\n        "geolocation": {\n          "altitude": 0,\n          "latitude": 0,\n          "longitude": 0,\n          "radius": 0\n        },\n        "id": 0,\n        "merchant_reference": "",\n        "monetary_account_id": 0,\n        "payment_auto_allocate_instance": {\n          "created": "",\n          "error_message": [],\n          "id": 0,\n          "payment_auto_allocate_id": 0,\n          "payment_batch": {\n            "payments": {\n              "Payment": []\n            }\n          },\n          "payment_id": 0,\n          "status": "",\n          "updated": ""\n        },\n        "request_reference_split_the_bill": [\n          {\n            "id": 0,\n            "type": ""\n          }\n        ],\n        "scheduled_id": 0,\n        "sub_type": "",\n        "type": "",\n        "updated": ""\n      },\n      "PaymentBatch": {}\n    },\n    "recurrence_size": 0,\n    "recurrence_unit": "",\n    "status": "",\n    "time_end": "",\n    "time_start": ""\n  },\n  "status": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "payment": [
    "alias": [
      "avatar": [
        "anchor_uuid": "",
        "image": [
          [
            "attachment_public_uuid": "",
            "content_type": "",
            "height": 0,
            "width": 0
          ]
        ],
        "style": "",
        "uuid": ""
      ],
      "bunq_me": [
        "name": "",
        "service": "",
        "type": "",
        "value": ""
      ],
      "country": "",
      "display_name": "",
      "iban": "",
      "is_light": false,
      "label_user": [
        "avatar": [],
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      ],
      "merchant_category_code": "",
      "swift_account_number": "",
      "swift_bic": "",
      "transferwise_account_number": "",
      "transferwise_bank_code": ""
    ],
    "allow_bunqto": false,
    "amount": [
      "currency": "",
      "value": ""
    ],
    "attachment": [
      [
        "id": 0,
        "monetary_account_id": 0
      ]
    ],
    "counterparty_alias": [],
    "description": "",
    "merchant_reference": ""
  ],
  "schedule": [
    "object": [
      "Payment": [
        "address_billing": [
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        ],
        "address_shipping": [],
        "alias": [],
        "allow_bunqto": false,
        "amount": [],
        "attachment": [[]],
        "balance_after_mutation": [],
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": [],
        "created": "",
        "description": "",
        "geolocation": [
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        ],
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": [
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": ["payments": ["Payment": []]],
          "payment_id": 0,
          "status": "",
          "updated": ""
        ],
        "request_reference_split_the_bill": [
          [
            "id": 0,
            "type": ""
          ]
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      ],
      "PaymentBatch": []
    ],
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  ],
  "status": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_SchedulePaymentBatch_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
BODY json

{
  "payments": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "allow_bunqto": false,
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "counterparty_alias": {},
      "description": "",
      "merchant_reference": ""
    }
  ],
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"payments\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"merchant_reference\": \"\"\n    }\n  ],\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch" {:headers {:user-agent ""
                                                                                                                               :x-bunq-client-authentication ""}
                                                                                                                     :content-type :json
                                                                                                                     :form-params {:payments [{:alias {:avatar {:anchor_uuid ""
                                                                                                                                                                :image [{:attachment_public_uuid ""
                                                                                                                                                                         :content_type ""
                                                                                                                                                                         :height 0
                                                                                                                                                                         :width 0}]
                                                                                                                                                                :style ""
                                                                                                                                                                :uuid ""}
                                                                                                                                                       :bunq_me {:name ""
                                                                                                                                                                 :service ""
                                                                                                                                                                 :type ""
                                                                                                                                                                 :value ""}
                                                                                                                                                       :country ""
                                                                                                                                                       :display_name ""
                                                                                                                                                       :iban ""
                                                                                                                                                       :is_light false
                                                                                                                                                       :label_user {:avatar {}
                                                                                                                                                                    :country ""
                                                                                                                                                                    :display_name ""
                                                                                                                                                                    :public_nick_name ""
                                                                                                                                                                    :uuid ""}
                                                                                                                                                       :merchant_category_code ""
                                                                                                                                                       :swift_account_number ""
                                                                                                                                                       :swift_bic ""
                                                                                                                                                       :transferwise_account_number ""
                                                                                                                                                       :transferwise_bank_code ""}
                                                                                                                                               :allow_bunqto false
                                                                                                                                               :amount {:currency ""
                                                                                                                                                        :value ""}
                                                                                                                                               :attachment [{:id 0
                                                                                                                                                             :monetary_account_id 0}]
                                                                                                                                               :counterparty_alias {}
                                                                                                                                               :description ""
                                                                                                                                               :merchant_reference ""}]
                                                                                                                                   :schedule {:object {:Payment {:address_billing {:city ""
                                                                                                                                                                                   :country ""
                                                                                                                                                                                   :extra ""
                                                                                                                                                                                   :house_number ""
                                                                                                                                                                                   :is_user_address_updated false
                                                                                                                                                                                   :mailbox_name ""
                                                                                                                                                                                   :po_box ""
                                                                                                                                                                                   :postal_code ""
                                                                                                                                                                                   :province ""
                                                                                                                                                                                   :street ""}
                                                                                                                                                                 :address_shipping {}
                                                                                                                                                                 :alias {}
                                                                                                                                                                 :allow_bunqto false
                                                                                                                                                                 :amount {}
                                                                                                                                                                 :attachment [{}]
                                                                                                                                                                 :balance_after_mutation {}
                                                                                                                                                                 :batch_id 0
                                                                                                                                                                 :bunqto_expiry ""
                                                                                                                                                                 :bunqto_share_url ""
                                                                                                                                                                 :bunqto_status ""
                                                                                                                                                                 :bunqto_sub_status ""
                                                                                                                                                                 :bunqto_time_responded ""
                                                                                                                                                                 :counterparty_alias {}
                                                                                                                                                                 :created ""
                                                                                                                                                                 :description ""
                                                                                                                                                                 :geolocation {:altitude 0
                                                                                                                                                                               :latitude 0
                                                                                                                                                                               :longitude 0
                                                                                                                                                                               :radius 0}
                                                                                                                                                                 :id 0
                                                                                                                                                                 :merchant_reference ""
                                                                                                                                                                 :monetary_account_id 0
                                                                                                                                                                 :payment_auto_allocate_instance {:created ""
                                                                                                                                                                                                  :error_message []
                                                                                                                                                                                                  :id 0
                                                                                                                                                                                                  :payment_auto_allocate_id 0
                                                                                                                                                                                                  :payment_batch {:payments {:Payment []}}
                                                                                                                                                                                                  :payment_id 0
                                                                                                                                                                                                  :status ""
                                                                                                                                                                                                  :updated ""}
                                                                                                                                                                 :request_reference_split_the_bill [{:id 0
                                                                                                                                                                                                     :type ""}]
                                                                                                                                                                 :scheduled_id 0
                                                                                                                                                                 :sub_type ""
                                                                                                                                                                 :type ""
                                                                                                                                                                 :updated ""}
                                                                                                                                                       :PaymentBatch {}}
                                                                                                                                              :recurrence_size 0
                                                                                                                                              :recurrence_unit ""
                                                                                                                                              :status ""
                                                                                                                                              :time_end ""
                                                                                                                                              :time_start ""}}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"payments\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"merchant_reference\": \"\"\n    }\n  ],\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  }\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"payments\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"merchant_reference\": \"\"\n    }\n  ],\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  }\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"payments\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"merchant_reference\": \"\"\n    }\n  ],\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch"

	payload := strings.NewReader("{\n  \"payments\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"merchant_reference\": \"\"\n    }\n  ],\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 2996

{
  "payments": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "allow_bunqto": false,
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "counterparty_alias": {},
      "description": "",
      "merchant_reference": ""
    }
  ],
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"payments\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"merchant_reference\": \"\"\n    }\n  ],\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"payments\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"merchant_reference\": \"\"\n    }\n  ],\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  }\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"payments\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"merchant_reference\": \"\"\n    }\n  ],\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"payments\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"merchant_reference\": \"\"\n    }\n  ],\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  payments: [
    {
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [
            {
              attachment_public_uuid: '',
              content_type: '',
              height: 0,
              width: 0
            }
          ],
          style: '',
          uuid: ''
        },
        bunq_me: {
          name: '',
          service: '',
          type: '',
          value: ''
        },
        country: '',
        display_name: '',
        iban: '',
        is_light: false,
        label_user: {
          avatar: {},
          country: '',
          display_name: '',
          public_nick_name: '',
          uuid: ''
        },
        merchant_category_code: '',
        swift_account_number: '',
        swift_bic: '',
        transferwise_account_number: '',
        transferwise_bank_code: ''
      },
      allow_bunqto: false,
      amount: {
        currency: '',
        value: ''
      },
      attachment: [
        {
          id: 0,
          monetary_account_id: 0
        }
      ],
      counterparty_alias: {},
      description: '',
      merchant_reference: ''
    }
  ],
  schedule: {
    object: {
      Payment: {
        address_billing: {
          city: '',
          country: '',
          extra: '',
          house_number: '',
          is_user_address_updated: false,
          mailbox_name: '',
          po_box: '',
          postal_code: '',
          province: '',
          street: ''
        },
        address_shipping: {},
        alias: {},
        allow_bunqto: false,
        amount: {},
        attachment: [
          {}
        ],
        balance_after_mutation: {},
        batch_id: 0,
        bunqto_expiry: '',
        bunqto_share_url: '',
        bunqto_status: '',
        bunqto_sub_status: '',
        bunqto_time_responded: '',
        counterparty_alias: {},
        created: '',
        description: '',
        geolocation: {
          altitude: 0,
          latitude: 0,
          longitude: 0,
          radius: 0
        },
        id: 0,
        merchant_reference: '',
        monetary_account_id: 0,
        payment_auto_allocate_instance: {
          created: '',
          error_message: [],
          id: 0,
          payment_auto_allocate_id: 0,
          payment_batch: {
            payments: {
              Payment: []
            }
          },
          payment_id: 0,
          status: '',
          updated: ''
        },
        request_reference_split_the_bill: [
          {
            id: 0,
            type: ''
          }
        ],
        scheduled_id: 0,
        sub_type: '',
        type: '',
        updated: ''
      },
      PaymentBatch: {}
    },
    recurrence_size: 0,
    recurrence_unit: '',
    status: '',
    time_end: '',
    time_start: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    payments: [
      {
        alias: {
          avatar: {
            anchor_uuid: '',
            image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
            style: '',
            uuid: ''
          },
          bunq_me: {name: '', service: '', type: '', value: ''},
          country: '',
          display_name: '',
          iban: '',
          is_light: false,
          label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
          merchant_category_code: '',
          swift_account_number: '',
          swift_bic: '',
          transferwise_account_number: '',
          transferwise_bank_code: ''
        },
        allow_bunqto: false,
        amount: {currency: '', value: ''},
        attachment: [{id: 0, monetary_account_id: 0}],
        counterparty_alias: {},
        description: '',
        merchant_reference: ''
      }
    ],
    schedule: {
      object: {
        Payment: {
          address_billing: {
            city: '',
            country: '',
            extra: '',
            house_number: '',
            is_user_address_updated: false,
            mailbox_name: '',
            po_box: '',
            postal_code: '',
            province: '',
            street: ''
          },
          address_shipping: {},
          alias: {},
          allow_bunqto: false,
          amount: {},
          attachment: [{}],
          balance_after_mutation: {},
          batch_id: 0,
          bunqto_expiry: '',
          bunqto_share_url: '',
          bunqto_status: '',
          bunqto_sub_status: '',
          bunqto_time_responded: '',
          counterparty_alias: {},
          created: '',
          description: '',
          geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
          id: 0,
          merchant_reference: '',
          monetary_account_id: 0,
          payment_auto_allocate_instance: {
            created: '',
            error_message: [],
            id: 0,
            payment_auto_allocate_id: 0,
            payment_batch: {payments: {Payment: []}},
            payment_id: 0,
            status: '',
            updated: ''
          },
          request_reference_split_the_bill: [{id: 0, type: ''}],
          scheduled_id: 0,
          sub_type: '',
          type: '',
          updated: ''
        },
        PaymentBatch: {}
      },
      recurrence_size: 0,
      recurrence_unit: '',
      status: '',
      time_end: '',
      time_start: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"payments":[{"alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"allow_bunqto":false,"amount":{"currency":"","value":""},"attachment":[{"id":0,"monetary_account_id":0}],"counterparty_alias":{},"description":"","merchant_reference":""}],"schedule":{"object":{"Payment":{"address_billing":{"city":"","country":"","extra":"","house_number":"","is_user_address_updated":false,"mailbox_name":"","po_box":"","postal_code":"","province":"","street":""},"address_shipping":{},"alias":{},"allow_bunqto":false,"amount":{},"attachment":[{}],"balance_after_mutation":{},"batch_id":0,"bunqto_expiry":"","bunqto_share_url":"","bunqto_status":"","bunqto_sub_status":"","bunqto_time_responded":"","counterparty_alias":{},"created":"","description":"","geolocation":{"altitude":0,"latitude":0,"longitude":0,"radius":0},"id":0,"merchant_reference":"","monetary_account_id":0,"payment_auto_allocate_instance":{"created":"","error_message":[],"id":0,"payment_auto_allocate_id":0,"payment_batch":{"payments":{"Payment":[]}},"payment_id":0,"status":"","updated":""},"request_reference_split_the_bill":[{"id":0,"type":""}],"scheduled_id":0,"sub_type":"","type":"","updated":""},"PaymentBatch":{}},"recurrence_size":0,"recurrence_unit":"","status":"","time_end":"","time_start":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "payments": [\n    {\n      "alias": {\n        "avatar": {\n          "anchor_uuid": "",\n          "image": [\n            {\n              "attachment_public_uuid": "",\n              "content_type": "",\n              "height": 0,\n              "width": 0\n            }\n          ],\n          "style": "",\n          "uuid": ""\n        },\n        "bunq_me": {\n          "name": "",\n          "service": "",\n          "type": "",\n          "value": ""\n        },\n        "country": "",\n        "display_name": "",\n        "iban": "",\n        "is_light": false,\n        "label_user": {\n          "avatar": {},\n          "country": "",\n          "display_name": "",\n          "public_nick_name": "",\n          "uuid": ""\n        },\n        "merchant_category_code": "",\n        "swift_account_number": "",\n        "swift_bic": "",\n        "transferwise_account_number": "",\n        "transferwise_bank_code": ""\n      },\n      "allow_bunqto": false,\n      "amount": {\n        "currency": "",\n        "value": ""\n      },\n      "attachment": [\n        {\n          "id": 0,\n          "monetary_account_id": 0\n        }\n      ],\n      "counterparty_alias": {},\n      "description": "",\n      "merchant_reference": ""\n    }\n  ],\n  "schedule": {\n    "object": {\n      "Payment": {\n        "address_billing": {\n          "city": "",\n          "country": "",\n          "extra": "",\n          "house_number": "",\n          "is_user_address_updated": false,\n          "mailbox_name": "",\n          "po_box": "",\n          "postal_code": "",\n          "province": "",\n          "street": ""\n        },\n        "address_shipping": {},\n        "alias": {},\n        "allow_bunqto": false,\n        "amount": {},\n        "attachment": [\n          {}\n        ],\n        "balance_after_mutation": {},\n        "batch_id": 0,\n        "bunqto_expiry": "",\n        "bunqto_share_url": "",\n        "bunqto_status": "",\n        "bunqto_sub_status": "",\n        "bunqto_time_responded": "",\n        "counterparty_alias": {},\n        "created": "",\n        "description": "",\n        "geolocation": {\n          "altitude": 0,\n          "latitude": 0,\n          "longitude": 0,\n          "radius": 0\n        },\n        "id": 0,\n        "merchant_reference": "",\n        "monetary_account_id": 0,\n        "payment_auto_allocate_instance": {\n          "created": "",\n          "error_message": [],\n          "id": 0,\n          "payment_auto_allocate_id": 0,\n          "payment_batch": {\n            "payments": {\n              "Payment": []\n            }\n          },\n          "payment_id": 0,\n          "status": "",\n          "updated": ""\n        },\n        "request_reference_split_the_bill": [\n          {\n            "id": 0,\n            "type": ""\n          }\n        ],\n        "scheduled_id": 0,\n        "sub_type": "",\n        "type": "",\n        "updated": ""\n      },\n      "PaymentBatch": {}\n    },\n    "recurrence_size": 0,\n    "recurrence_unit": "",\n    "status": "",\n    "time_end": "",\n    "time_start": ""\n  }\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"payments\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"merchant_reference\": \"\"\n    }\n  ],\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  payments: [
    {
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
          style: '',
          uuid: ''
        },
        bunq_me: {name: '', service: '', type: '', value: ''},
        country: '',
        display_name: '',
        iban: '',
        is_light: false,
        label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
        merchant_category_code: '',
        swift_account_number: '',
        swift_bic: '',
        transferwise_account_number: '',
        transferwise_bank_code: ''
      },
      allow_bunqto: false,
      amount: {currency: '', value: ''},
      attachment: [{id: 0, monetary_account_id: 0}],
      counterparty_alias: {},
      description: '',
      merchant_reference: ''
    }
  ],
  schedule: {
    object: {
      Payment: {
        address_billing: {
          city: '',
          country: '',
          extra: '',
          house_number: '',
          is_user_address_updated: false,
          mailbox_name: '',
          po_box: '',
          postal_code: '',
          province: '',
          street: ''
        },
        address_shipping: {},
        alias: {},
        allow_bunqto: false,
        amount: {},
        attachment: [{}],
        balance_after_mutation: {},
        batch_id: 0,
        bunqto_expiry: '',
        bunqto_share_url: '',
        bunqto_status: '',
        bunqto_sub_status: '',
        bunqto_time_responded: '',
        counterparty_alias: {},
        created: '',
        description: '',
        geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
        id: 0,
        merchant_reference: '',
        monetary_account_id: 0,
        payment_auto_allocate_instance: {
          created: '',
          error_message: [],
          id: 0,
          payment_auto_allocate_id: 0,
          payment_batch: {payments: {Payment: []}},
          payment_id: 0,
          status: '',
          updated: ''
        },
        request_reference_split_the_bill: [{id: 0, type: ''}],
        scheduled_id: 0,
        sub_type: '',
        type: '',
        updated: ''
      },
      PaymentBatch: {}
    },
    recurrence_size: 0,
    recurrence_unit: '',
    status: '',
    time_end: '',
    time_start: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    payments: [
      {
        alias: {
          avatar: {
            anchor_uuid: '',
            image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
            style: '',
            uuid: ''
          },
          bunq_me: {name: '', service: '', type: '', value: ''},
          country: '',
          display_name: '',
          iban: '',
          is_light: false,
          label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
          merchant_category_code: '',
          swift_account_number: '',
          swift_bic: '',
          transferwise_account_number: '',
          transferwise_bank_code: ''
        },
        allow_bunqto: false,
        amount: {currency: '', value: ''},
        attachment: [{id: 0, monetary_account_id: 0}],
        counterparty_alias: {},
        description: '',
        merchant_reference: ''
      }
    ],
    schedule: {
      object: {
        Payment: {
          address_billing: {
            city: '',
            country: '',
            extra: '',
            house_number: '',
            is_user_address_updated: false,
            mailbox_name: '',
            po_box: '',
            postal_code: '',
            province: '',
            street: ''
          },
          address_shipping: {},
          alias: {},
          allow_bunqto: false,
          amount: {},
          attachment: [{}],
          balance_after_mutation: {},
          batch_id: 0,
          bunqto_expiry: '',
          bunqto_share_url: '',
          bunqto_status: '',
          bunqto_sub_status: '',
          bunqto_time_responded: '',
          counterparty_alias: {},
          created: '',
          description: '',
          geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
          id: 0,
          merchant_reference: '',
          monetary_account_id: 0,
          payment_auto_allocate_instance: {
            created: '',
            error_message: [],
            id: 0,
            payment_auto_allocate_id: 0,
            payment_batch: {payments: {Payment: []}},
            payment_id: 0,
            status: '',
            updated: ''
          },
          request_reference_split_the_bill: [{id: 0, type: ''}],
          scheduled_id: 0,
          sub_type: '',
          type: '',
          updated: ''
        },
        PaymentBatch: {}
      },
      recurrence_size: 0,
      recurrence_unit: '',
      status: '',
      time_end: '',
      time_start: ''
    }
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  payments: [
    {
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [
            {
              attachment_public_uuid: '',
              content_type: '',
              height: 0,
              width: 0
            }
          ],
          style: '',
          uuid: ''
        },
        bunq_me: {
          name: '',
          service: '',
          type: '',
          value: ''
        },
        country: '',
        display_name: '',
        iban: '',
        is_light: false,
        label_user: {
          avatar: {},
          country: '',
          display_name: '',
          public_nick_name: '',
          uuid: ''
        },
        merchant_category_code: '',
        swift_account_number: '',
        swift_bic: '',
        transferwise_account_number: '',
        transferwise_bank_code: ''
      },
      allow_bunqto: false,
      amount: {
        currency: '',
        value: ''
      },
      attachment: [
        {
          id: 0,
          monetary_account_id: 0
        }
      ],
      counterparty_alias: {},
      description: '',
      merchant_reference: ''
    }
  ],
  schedule: {
    object: {
      Payment: {
        address_billing: {
          city: '',
          country: '',
          extra: '',
          house_number: '',
          is_user_address_updated: false,
          mailbox_name: '',
          po_box: '',
          postal_code: '',
          province: '',
          street: ''
        },
        address_shipping: {},
        alias: {},
        allow_bunqto: false,
        amount: {},
        attachment: [
          {}
        ],
        balance_after_mutation: {},
        batch_id: 0,
        bunqto_expiry: '',
        bunqto_share_url: '',
        bunqto_status: '',
        bunqto_sub_status: '',
        bunqto_time_responded: '',
        counterparty_alias: {},
        created: '',
        description: '',
        geolocation: {
          altitude: 0,
          latitude: 0,
          longitude: 0,
          radius: 0
        },
        id: 0,
        merchant_reference: '',
        monetary_account_id: 0,
        payment_auto_allocate_instance: {
          created: '',
          error_message: [],
          id: 0,
          payment_auto_allocate_id: 0,
          payment_batch: {
            payments: {
              Payment: []
            }
          },
          payment_id: 0,
          status: '',
          updated: ''
        },
        request_reference_split_the_bill: [
          {
            id: 0,
            type: ''
          }
        ],
        scheduled_id: 0,
        sub_type: '',
        type: '',
        updated: ''
      },
      PaymentBatch: {}
    },
    recurrence_size: 0,
    recurrence_unit: '',
    status: '',
    time_end: '',
    time_start: ''
  }
});

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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    payments: [
      {
        alias: {
          avatar: {
            anchor_uuid: '',
            image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
            style: '',
            uuid: ''
          },
          bunq_me: {name: '', service: '', type: '', value: ''},
          country: '',
          display_name: '',
          iban: '',
          is_light: false,
          label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
          merchant_category_code: '',
          swift_account_number: '',
          swift_bic: '',
          transferwise_account_number: '',
          transferwise_bank_code: ''
        },
        allow_bunqto: false,
        amount: {currency: '', value: ''},
        attachment: [{id: 0, monetary_account_id: 0}],
        counterparty_alias: {},
        description: '',
        merchant_reference: ''
      }
    ],
    schedule: {
      object: {
        Payment: {
          address_billing: {
            city: '',
            country: '',
            extra: '',
            house_number: '',
            is_user_address_updated: false,
            mailbox_name: '',
            po_box: '',
            postal_code: '',
            province: '',
            street: ''
          },
          address_shipping: {},
          alias: {},
          allow_bunqto: false,
          amount: {},
          attachment: [{}],
          balance_after_mutation: {},
          batch_id: 0,
          bunqto_expiry: '',
          bunqto_share_url: '',
          bunqto_status: '',
          bunqto_sub_status: '',
          bunqto_time_responded: '',
          counterparty_alias: {},
          created: '',
          description: '',
          geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
          id: 0,
          merchant_reference: '',
          monetary_account_id: 0,
          payment_auto_allocate_instance: {
            created: '',
            error_message: [],
            id: 0,
            payment_auto_allocate_id: 0,
            payment_batch: {payments: {Payment: []}},
            payment_id: 0,
            status: '',
            updated: ''
          },
          request_reference_split_the_bill: [{id: 0, type: ''}],
          scheduled_id: 0,
          sub_type: '',
          type: '',
          updated: ''
        },
        PaymentBatch: {}
      },
      recurrence_size: 0,
      recurrence_unit: '',
      status: '',
      time_end: '',
      time_start: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"payments":[{"alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"allow_bunqto":false,"amount":{"currency":"","value":""},"attachment":[{"id":0,"monetary_account_id":0}],"counterparty_alias":{},"description":"","merchant_reference":""}],"schedule":{"object":{"Payment":{"address_billing":{"city":"","country":"","extra":"","house_number":"","is_user_address_updated":false,"mailbox_name":"","po_box":"","postal_code":"","province":"","street":""},"address_shipping":{},"alias":{},"allow_bunqto":false,"amount":{},"attachment":[{}],"balance_after_mutation":{},"batch_id":0,"bunqto_expiry":"","bunqto_share_url":"","bunqto_status":"","bunqto_sub_status":"","bunqto_time_responded":"","counterparty_alias":{},"created":"","description":"","geolocation":{"altitude":0,"latitude":0,"longitude":0,"radius":0},"id":0,"merchant_reference":"","monetary_account_id":0,"payment_auto_allocate_instance":{"created":"","error_message":[],"id":0,"payment_auto_allocate_id":0,"payment_batch":{"payments":{"Payment":[]}},"payment_id":0,"status":"","updated":""},"request_reference_split_the_bill":[{"id":0,"type":""}],"scheduled_id":0,"sub_type":"","type":"","updated":""},"PaymentBatch":{}},"recurrence_size":0,"recurrence_unit":"","status":"","time_end":"","time_start":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"payments": @[ @{ @"alias": @{ @"avatar": @{ @"anchor_uuid": @"", @"image": @[ @{ @"attachment_public_uuid": @"", @"content_type": @"", @"height": @0, @"width": @0 } ], @"style": @"", @"uuid": @"" }, @"bunq_me": @{ @"name": @"", @"service": @"", @"type": @"", @"value": @"" }, @"country": @"", @"display_name": @"", @"iban": @"", @"is_light": @NO, @"label_user": @{ @"avatar": @{  }, @"country": @"", @"display_name": @"", @"public_nick_name": @"", @"uuid": @"" }, @"merchant_category_code": @"", @"swift_account_number": @"", @"swift_bic": @"", @"transferwise_account_number": @"", @"transferwise_bank_code": @"" }, @"allow_bunqto": @NO, @"amount": @{ @"currency": @"", @"value": @"" }, @"attachment": @[ @{ @"id": @0, @"monetary_account_id": @0 } ], @"counterparty_alias": @{  }, @"description": @"", @"merchant_reference": @"" } ],
                              @"schedule": @{ @"object": @{ @"Payment": @{ @"address_billing": @{ @"city": @"", @"country": @"", @"extra": @"", @"house_number": @"", @"is_user_address_updated": @NO, @"mailbox_name": @"", @"po_box": @"", @"postal_code": @"", @"province": @"", @"street": @"" }, @"address_shipping": @{  }, @"alias": @{  }, @"allow_bunqto": @NO, @"amount": @{  }, @"attachment": @[ @{  } ], @"balance_after_mutation": @{  }, @"batch_id": @0, @"bunqto_expiry": @"", @"bunqto_share_url": @"", @"bunqto_status": @"", @"bunqto_sub_status": @"", @"bunqto_time_responded": @"", @"counterparty_alias": @{  }, @"created": @"", @"description": @"", @"geolocation": @{ @"altitude": @0, @"latitude": @0, @"longitude": @0, @"radius": @0 }, @"id": @0, @"merchant_reference": @"", @"monetary_account_id": @0, @"payment_auto_allocate_instance": @{ @"created": @"", @"error_message": @[  ], @"id": @0, @"payment_auto_allocate_id": @0, @"payment_batch": @{ @"payments": @{ @"Payment": @[  ] } }, @"payment_id": @0, @"status": @"", @"updated": @"" }, @"request_reference_split_the_bill": @[ @{ @"id": @0, @"type": @"" } ], @"scheduled_id": @0, @"sub_type": @"", @"type": @"", @"updated": @"" }, @"PaymentBatch": @{  } }, @"recurrence_size": @0, @"recurrence_unit": @"", @"status": @"", @"time_end": @"", @"time_start": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"payments\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"merchant_reference\": \"\"\n    }\n  ],\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'payments' => [
        [
                'alias' => [
                                'avatar' => [
                                                                'anchor_uuid' => '',
                                                                'image' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'attachment_public_uuid' => '',
                                                                                                                                                                                                                                                                'content_type' => '',
                                                                                                                                                                                                                                                                'height' => 0,
                                                                                                                                                                                                                                                                'width' => 0
                                                                                                                                ]
                                                                ],
                                                                'style' => '',
                                                                'uuid' => ''
                                ],
                                'bunq_me' => [
                                                                'name' => '',
                                                                'service' => '',
                                                                'type' => '',
                                                                'value' => ''
                                ],
                                'country' => '',
                                'display_name' => '',
                                'iban' => '',
                                'is_light' => null,
                                'label_user' => [
                                                                'avatar' => [
                                                                                                                                
                                                                ],
                                                                'country' => '',
                                                                'display_name' => '',
                                                                'public_nick_name' => '',
                                                                'uuid' => ''
                                ],
                                'merchant_category_code' => '',
                                'swift_account_number' => '',
                                'swift_bic' => '',
                                'transferwise_account_number' => '',
                                'transferwise_bank_code' => ''
                ],
                'allow_bunqto' => null,
                'amount' => [
                                'currency' => '',
                                'value' => ''
                ],
                'attachment' => [
                                [
                                                                'id' => 0,
                                                                'monetary_account_id' => 0
                                ]
                ],
                'counterparty_alias' => [
                                
                ],
                'description' => '',
                'merchant_reference' => ''
        ]
    ],
    'schedule' => [
        'object' => [
                'Payment' => [
                                'address_billing' => [
                                                                'city' => '',
                                                                'country' => '',
                                                                'extra' => '',
                                                                'house_number' => '',
                                                                'is_user_address_updated' => null,
                                                                'mailbox_name' => '',
                                                                'po_box' => '',
                                                                'postal_code' => '',
                                                                'province' => '',
                                                                'street' => ''
                                ],
                                'address_shipping' => [
                                                                
                                ],
                                'alias' => [
                                                                
                                ],
                                'allow_bunqto' => null,
                                'amount' => [
                                                                
                                ],
                                'attachment' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'balance_after_mutation' => [
                                                                
                                ],
                                'batch_id' => 0,
                                'bunqto_expiry' => '',
                                'bunqto_share_url' => '',
                                'bunqto_status' => '',
                                'bunqto_sub_status' => '',
                                'bunqto_time_responded' => '',
                                'counterparty_alias' => [
                                                                
                                ],
                                'created' => '',
                                'description' => '',
                                'geolocation' => [
                                                                'altitude' => 0,
                                                                'latitude' => 0,
                                                                'longitude' => 0,
                                                                'radius' => 0
                                ],
                                'id' => 0,
                                'merchant_reference' => '',
                                'monetary_account_id' => 0,
                                'payment_auto_allocate_instance' => [
                                                                'created' => '',
                                                                'error_message' => [
                                                                                                                                
                                                                ],
                                                                'id' => 0,
                                                                'payment_auto_allocate_id' => 0,
                                                                'payment_batch' => [
                                                                                                                                'payments' => [
                                                                                                                                                                                                                                                                'Payment' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ]
                                                                                                                                ]
                                                                ],
                                                                'payment_id' => 0,
                                                                'status' => '',
                                                                'updated' => ''
                                ],
                                'request_reference_split_the_bill' => [
                                                                [
                                                                                                                                'id' => 0,
                                                                                                                                'type' => ''
                                                                ]
                                ],
                                'scheduled_id' => 0,
                                'sub_type' => '',
                                'type' => '',
                                'updated' => ''
                ],
                'PaymentBatch' => [
                                
                ]
        ],
        'recurrence_size' => 0,
        'recurrence_unit' => '',
        'status' => '',
        'time_end' => '',
        'time_start' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch', [
  'body' => '{
  "payments": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "allow_bunqto": false,
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "counterparty_alias": {},
      "description": "",
      "merchant_reference": ""
    }
  ],
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'payments' => [
    [
        'alias' => [
                'avatar' => [
                                'anchor_uuid' => '',
                                'image' => [
                                                                [
                                                                                                                                'attachment_public_uuid' => '',
                                                                                                                                'content_type' => '',
                                                                                                                                'height' => 0,
                                                                                                                                'width' => 0
                                                                ]
                                ],
                                'style' => '',
                                'uuid' => ''
                ],
                'bunq_me' => [
                                'name' => '',
                                'service' => '',
                                'type' => '',
                                'value' => ''
                ],
                'country' => '',
                'display_name' => '',
                'iban' => '',
                'is_light' => null,
                'label_user' => [
                                'avatar' => [
                                                                
                                ],
                                'country' => '',
                                'display_name' => '',
                                'public_nick_name' => '',
                                'uuid' => ''
                ],
                'merchant_category_code' => '',
                'swift_account_number' => '',
                'swift_bic' => '',
                'transferwise_account_number' => '',
                'transferwise_bank_code' => ''
        ],
        'allow_bunqto' => null,
        'amount' => [
                'currency' => '',
                'value' => ''
        ],
        'attachment' => [
                [
                                'id' => 0,
                                'monetary_account_id' => 0
                ]
        ],
        'counterparty_alias' => [
                
        ],
        'description' => '',
        'merchant_reference' => ''
    ]
  ],
  'schedule' => [
    'object' => [
        'Payment' => [
                'address_billing' => [
                                'city' => '',
                                'country' => '',
                                'extra' => '',
                                'house_number' => '',
                                'is_user_address_updated' => null,
                                'mailbox_name' => '',
                                'po_box' => '',
                                'postal_code' => '',
                                'province' => '',
                                'street' => ''
                ],
                'address_shipping' => [
                                
                ],
                'alias' => [
                                
                ],
                'allow_bunqto' => null,
                'amount' => [
                                
                ],
                'attachment' => [
                                [
                                                                
                                ]
                ],
                'balance_after_mutation' => [
                                
                ],
                'batch_id' => 0,
                'bunqto_expiry' => '',
                'bunqto_share_url' => '',
                'bunqto_status' => '',
                'bunqto_sub_status' => '',
                'bunqto_time_responded' => '',
                'counterparty_alias' => [
                                
                ],
                'created' => '',
                'description' => '',
                'geolocation' => [
                                'altitude' => 0,
                                'latitude' => 0,
                                'longitude' => 0,
                                'radius' => 0
                ],
                'id' => 0,
                'merchant_reference' => '',
                'monetary_account_id' => 0,
                'payment_auto_allocate_instance' => [
                                'created' => '',
                                'error_message' => [
                                                                
                                ],
                                'id' => 0,
                                'payment_auto_allocate_id' => 0,
                                'payment_batch' => [
                                                                'payments' => [
                                                                                                                                'Payment' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'payment_id' => 0,
                                'status' => '',
                                'updated' => ''
                ],
                'request_reference_split_the_bill' => [
                                [
                                                                'id' => 0,
                                                                'type' => ''
                                ]
                ],
                'scheduled_id' => 0,
                'sub_type' => '',
                'type' => '',
                'updated' => ''
        ],
        'PaymentBatch' => [
                
        ]
    ],
    'recurrence_size' => 0,
    'recurrence_unit' => '',
    'status' => '',
    'time_end' => '',
    'time_start' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'payments' => [
    [
        'alias' => [
                'avatar' => [
                                'anchor_uuid' => '',
                                'image' => [
                                                                [
                                                                                                                                'attachment_public_uuid' => '',
                                                                                                                                'content_type' => '',
                                                                                                                                'height' => 0,
                                                                                                                                'width' => 0
                                                                ]
                                ],
                                'style' => '',
                                'uuid' => ''
                ],
                'bunq_me' => [
                                'name' => '',
                                'service' => '',
                                'type' => '',
                                'value' => ''
                ],
                'country' => '',
                'display_name' => '',
                'iban' => '',
                'is_light' => null,
                'label_user' => [
                                'avatar' => [
                                                                
                                ],
                                'country' => '',
                                'display_name' => '',
                                'public_nick_name' => '',
                                'uuid' => ''
                ],
                'merchant_category_code' => '',
                'swift_account_number' => '',
                'swift_bic' => '',
                'transferwise_account_number' => '',
                'transferwise_bank_code' => ''
        ],
        'allow_bunqto' => null,
        'amount' => [
                'currency' => '',
                'value' => ''
        ],
        'attachment' => [
                [
                                'id' => 0,
                                'monetary_account_id' => 0
                ]
        ],
        'counterparty_alias' => [
                
        ],
        'description' => '',
        'merchant_reference' => ''
    ]
  ],
  'schedule' => [
    'object' => [
        'Payment' => [
                'address_billing' => [
                                'city' => '',
                                'country' => '',
                                'extra' => '',
                                'house_number' => '',
                                'is_user_address_updated' => null,
                                'mailbox_name' => '',
                                'po_box' => '',
                                'postal_code' => '',
                                'province' => '',
                                'street' => ''
                ],
                'address_shipping' => [
                                
                ],
                'alias' => [
                                
                ],
                'allow_bunqto' => null,
                'amount' => [
                                
                ],
                'attachment' => [
                                [
                                                                
                                ]
                ],
                'balance_after_mutation' => [
                                
                ],
                'batch_id' => 0,
                'bunqto_expiry' => '',
                'bunqto_share_url' => '',
                'bunqto_status' => '',
                'bunqto_sub_status' => '',
                'bunqto_time_responded' => '',
                'counterparty_alias' => [
                                
                ],
                'created' => '',
                'description' => '',
                'geolocation' => [
                                'altitude' => 0,
                                'latitude' => 0,
                                'longitude' => 0,
                                'radius' => 0
                ],
                'id' => 0,
                'merchant_reference' => '',
                'monetary_account_id' => 0,
                'payment_auto_allocate_instance' => [
                                'created' => '',
                                'error_message' => [
                                                                
                                ],
                                'id' => 0,
                                'payment_auto_allocate_id' => 0,
                                'payment_batch' => [
                                                                'payments' => [
                                                                                                                                'Payment' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'payment_id' => 0,
                                'status' => '',
                                'updated' => ''
                ],
                'request_reference_split_the_bill' => [
                                [
                                                                'id' => 0,
                                                                'type' => ''
                                ]
                ],
                'scheduled_id' => 0,
                'sub_type' => '',
                'type' => '',
                'updated' => ''
        ],
        'PaymentBatch' => [
                
        ]
    ],
    'recurrence_size' => 0,
    'recurrence_unit' => '',
    'status' => '',
    'time_end' => '',
    'time_start' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "payments": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "allow_bunqto": false,
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "counterparty_alias": {},
      "description": "",
      "merchant_reference": ""
    }
  ],
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  }
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "payments": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "allow_bunqto": false,
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "counterparty_alias": {},
      "description": "",
      "merchant_reference": ""
    }
  ],
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"payments\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"merchant_reference\": \"\"\n    }\n  ],\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  }\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch"

payload = {
    "payments": [
        {
            "alias": {
                "avatar": {
                    "anchor_uuid": "",
                    "image": [
                        {
                            "attachment_public_uuid": "",
                            "content_type": "",
                            "height": 0,
                            "width": 0
                        }
                    ],
                    "style": "",
                    "uuid": ""
                },
                "bunq_me": {
                    "name": "",
                    "service": "",
                    "type": "",
                    "value": ""
                },
                "country": "",
                "display_name": "",
                "iban": "",
                "is_light": False,
                "label_user": {
                    "avatar": {},
                    "country": "",
                    "display_name": "",
                    "public_nick_name": "",
                    "uuid": ""
                },
                "merchant_category_code": "",
                "swift_account_number": "",
                "swift_bic": "",
                "transferwise_account_number": "",
                "transferwise_bank_code": ""
            },
            "allow_bunqto": False,
            "amount": {
                "currency": "",
                "value": ""
            },
            "attachment": [
                {
                    "id": 0,
                    "monetary_account_id": 0
                }
            ],
            "counterparty_alias": {},
            "description": "",
            "merchant_reference": ""
        }
    ],
    "schedule": {
        "object": {
            "Payment": {
                "address_billing": {
                    "city": "",
                    "country": "",
                    "extra": "",
                    "house_number": "",
                    "is_user_address_updated": False,
                    "mailbox_name": "",
                    "po_box": "",
                    "postal_code": "",
                    "province": "",
                    "street": ""
                },
                "address_shipping": {},
                "alias": {},
                "allow_bunqto": False,
                "amount": {},
                "attachment": [{}],
                "balance_after_mutation": {},
                "batch_id": 0,
                "bunqto_expiry": "",
                "bunqto_share_url": "",
                "bunqto_status": "",
                "bunqto_sub_status": "",
                "bunqto_time_responded": "",
                "counterparty_alias": {},
                "created": "",
                "description": "",
                "geolocation": {
                    "altitude": 0,
                    "latitude": 0,
                    "longitude": 0,
                    "radius": 0
                },
                "id": 0,
                "merchant_reference": "",
                "monetary_account_id": 0,
                "payment_auto_allocate_instance": {
                    "created": "",
                    "error_message": [],
                    "id": 0,
                    "payment_auto_allocate_id": 0,
                    "payment_batch": { "payments": { "Payment": [] } },
                    "payment_id": 0,
                    "status": "",
                    "updated": ""
                },
                "request_reference_split_the_bill": [
                    {
                        "id": 0,
                        "type": ""
                    }
                ],
                "scheduled_id": 0,
                "sub_type": "",
                "type": "",
                "updated": ""
            },
            "PaymentBatch": {}
        },
        "recurrence_size": 0,
        "recurrence_unit": "",
        "status": "",
        "time_end": "",
        "time_start": ""
    }
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch"

payload <- "{\n  \"payments\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"merchant_reference\": \"\"\n    }\n  ],\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"payments\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"merchant_reference\": \"\"\n    }\n  ],\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  }\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"payments\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"merchant_reference\": \"\"\n    }\n  ],\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch";

    let payload = json!({
        "payments": (
            json!({
                "alias": json!({
                    "avatar": json!({
                        "anchor_uuid": "",
                        "image": (
                            json!({
                                "attachment_public_uuid": "",
                                "content_type": "",
                                "height": 0,
                                "width": 0
                            })
                        ),
                        "style": "",
                        "uuid": ""
                    }),
                    "bunq_me": json!({
                        "name": "",
                        "service": "",
                        "type": "",
                        "value": ""
                    }),
                    "country": "",
                    "display_name": "",
                    "iban": "",
                    "is_light": false,
                    "label_user": json!({
                        "avatar": json!({}),
                        "country": "",
                        "display_name": "",
                        "public_nick_name": "",
                        "uuid": ""
                    }),
                    "merchant_category_code": "",
                    "swift_account_number": "",
                    "swift_bic": "",
                    "transferwise_account_number": "",
                    "transferwise_bank_code": ""
                }),
                "allow_bunqto": false,
                "amount": json!({
                    "currency": "",
                    "value": ""
                }),
                "attachment": (
                    json!({
                        "id": 0,
                        "monetary_account_id": 0
                    })
                ),
                "counterparty_alias": json!({}),
                "description": "",
                "merchant_reference": ""
            })
        ),
        "schedule": json!({
            "object": json!({
                "Payment": json!({
                    "address_billing": json!({
                        "city": "",
                        "country": "",
                        "extra": "",
                        "house_number": "",
                        "is_user_address_updated": false,
                        "mailbox_name": "",
                        "po_box": "",
                        "postal_code": "",
                        "province": "",
                        "street": ""
                    }),
                    "address_shipping": json!({}),
                    "alias": json!({}),
                    "allow_bunqto": false,
                    "amount": json!({}),
                    "attachment": (json!({})),
                    "balance_after_mutation": json!({}),
                    "batch_id": 0,
                    "bunqto_expiry": "",
                    "bunqto_share_url": "",
                    "bunqto_status": "",
                    "bunqto_sub_status": "",
                    "bunqto_time_responded": "",
                    "counterparty_alias": json!({}),
                    "created": "",
                    "description": "",
                    "geolocation": json!({
                        "altitude": 0,
                        "latitude": 0,
                        "longitude": 0,
                        "radius": 0
                    }),
                    "id": 0,
                    "merchant_reference": "",
                    "monetary_account_id": 0,
                    "payment_auto_allocate_instance": json!({
                        "created": "",
                        "error_message": (),
                        "id": 0,
                        "payment_auto_allocate_id": 0,
                        "payment_batch": json!({"payments": json!({"Payment": ()})}),
                        "payment_id": 0,
                        "status": "",
                        "updated": ""
                    }),
                    "request_reference_split_the_bill": (
                        json!({
                            "id": 0,
                            "type": ""
                        })
                    ),
                    "scheduled_id": 0,
                    "sub_type": "",
                    "type": "",
                    "updated": ""
                }),
                "PaymentBatch": json!({})
            }),
            "recurrence_size": 0,
            "recurrence_unit": "",
            "status": "",
            "time_end": "",
            "time_start": ""
        })
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "payments": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "allow_bunqto": false,
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "counterparty_alias": {},
      "description": "",
      "merchant_reference": ""
    }
  ],
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  }
}'
echo '{
  "payments": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "allow_bunqto": false,
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "counterparty_alias": {},
      "description": "",
      "merchant_reference": ""
    }
  ],
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  }
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "payments": [\n    {\n      "alias": {\n        "avatar": {\n          "anchor_uuid": "",\n          "image": [\n            {\n              "attachment_public_uuid": "",\n              "content_type": "",\n              "height": 0,\n              "width": 0\n            }\n          ],\n          "style": "",\n          "uuid": ""\n        },\n        "bunq_me": {\n          "name": "",\n          "service": "",\n          "type": "",\n          "value": ""\n        },\n        "country": "",\n        "display_name": "",\n        "iban": "",\n        "is_light": false,\n        "label_user": {\n          "avatar": {},\n          "country": "",\n          "display_name": "",\n          "public_nick_name": "",\n          "uuid": ""\n        },\n        "merchant_category_code": "",\n        "swift_account_number": "",\n        "swift_bic": "",\n        "transferwise_account_number": "",\n        "transferwise_bank_code": ""\n      },\n      "allow_bunqto": false,\n      "amount": {\n        "currency": "",\n        "value": ""\n      },\n      "attachment": [\n        {\n          "id": 0,\n          "monetary_account_id": 0\n        }\n      ],\n      "counterparty_alias": {},\n      "description": "",\n      "merchant_reference": ""\n    }\n  ],\n  "schedule": {\n    "object": {\n      "Payment": {\n        "address_billing": {\n          "city": "",\n          "country": "",\n          "extra": "",\n          "house_number": "",\n          "is_user_address_updated": false,\n          "mailbox_name": "",\n          "po_box": "",\n          "postal_code": "",\n          "province": "",\n          "street": ""\n        },\n        "address_shipping": {},\n        "alias": {},\n        "allow_bunqto": false,\n        "amount": {},\n        "attachment": [\n          {}\n        ],\n        "balance_after_mutation": {},\n        "batch_id": 0,\n        "bunqto_expiry": "",\n        "bunqto_share_url": "",\n        "bunqto_status": "",\n        "bunqto_sub_status": "",\n        "bunqto_time_responded": "",\n        "counterparty_alias": {},\n        "created": "",\n        "description": "",\n        "geolocation": {\n          "altitude": 0,\n          "latitude": 0,\n          "longitude": 0,\n          "radius": 0\n        },\n        "id": 0,\n        "merchant_reference": "",\n        "monetary_account_id": 0,\n        "payment_auto_allocate_instance": {\n          "created": "",\n          "error_message": [],\n          "id": 0,\n          "payment_auto_allocate_id": 0,\n          "payment_batch": {\n            "payments": {\n              "Payment": []\n            }\n          },\n          "payment_id": 0,\n          "status": "",\n          "updated": ""\n        },\n        "request_reference_split_the_bill": [\n          {\n            "id": 0,\n            "type": ""\n          }\n        ],\n        "scheduled_id": 0,\n        "sub_type": "",\n        "type": "",\n        "updated": ""\n      },\n      "PaymentBatch": {}\n    },\n    "recurrence_size": 0,\n    "recurrence_unit": "",\n    "status": "",\n    "time_end": "",\n    "time_start": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "payments": [
    [
      "alias": [
        "avatar": [
          "anchor_uuid": "",
          "image": [
            [
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            ]
          ],
          "style": "",
          "uuid": ""
        ],
        "bunq_me": [
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        ],
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": [
          "avatar": [],
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        ],
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      ],
      "allow_bunqto": false,
      "amount": [
        "currency": "",
        "value": ""
      ],
      "attachment": [
        [
          "id": 0,
          "monetary_account_id": 0
        ]
      ],
      "counterparty_alias": [],
      "description": "",
      "merchant_reference": ""
    ]
  ],
  "schedule": [
    "object": [
      "Payment": [
        "address_billing": [
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        ],
        "address_shipping": [],
        "alias": [],
        "allow_bunqto": false,
        "amount": [],
        "attachment": [[]],
        "balance_after_mutation": [],
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": [],
        "created": "",
        "description": "",
        "geolocation": [
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        ],
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": [
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": ["payments": ["Payment": []]],
          "payment_id": 0,
          "status": "",
          "updated": ""
        ],
        "request_reference_split_the_bill": [
          [
            "id": 0,
            "type": ""
          ]
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      ],
      "PaymentBatch": []
    ],
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  ]
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_SchedulePaymentBatch_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId" {:headers {:user-agent ""
                                                                                                                                         :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId"]
                                                       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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_SchedulePaymentBatch_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId" {:headers {:user-agent ""
                                                                                                                                      :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_SchedulePaymentBatch_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
itemId
BODY json

{
  "payments": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "allow_bunqto": false,
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "counterparty_alias": {},
      "description": "",
      "merchant_reference": ""
    }
  ],
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"payments\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"merchant_reference\": \"\"\n    }\n  ],\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId" {:headers {:user-agent ""
                                                                                                                                      :x-bunq-client-authentication ""}
                                                                                                                            :content-type :json
                                                                                                                            :form-params {:payments [{:alias {:avatar {:anchor_uuid ""
                                                                                                                                                                       :image [{:attachment_public_uuid ""
                                                                                                                                                                                :content_type ""
                                                                                                                                                                                :height 0
                                                                                                                                                                                :width 0}]
                                                                                                                                                                       :style ""
                                                                                                                                                                       :uuid ""}
                                                                                                                                                              :bunq_me {:name ""
                                                                                                                                                                        :service ""
                                                                                                                                                                        :type ""
                                                                                                                                                                        :value ""}
                                                                                                                                                              :country ""
                                                                                                                                                              :display_name ""
                                                                                                                                                              :iban ""
                                                                                                                                                              :is_light false
                                                                                                                                                              :label_user {:avatar {}
                                                                                                                                                                           :country ""
                                                                                                                                                                           :display_name ""
                                                                                                                                                                           :public_nick_name ""
                                                                                                                                                                           :uuid ""}
                                                                                                                                                              :merchant_category_code ""
                                                                                                                                                              :swift_account_number ""
                                                                                                                                                              :swift_bic ""
                                                                                                                                                              :transferwise_account_number ""
                                                                                                                                                              :transferwise_bank_code ""}
                                                                                                                                                      :allow_bunqto false
                                                                                                                                                      :amount {:currency ""
                                                                                                                                                               :value ""}
                                                                                                                                                      :attachment [{:id 0
                                                                                                                                                                    :monetary_account_id 0}]
                                                                                                                                                      :counterparty_alias {}
                                                                                                                                                      :description ""
                                                                                                                                                      :merchant_reference ""}]
                                                                                                                                          :schedule {:object {:Payment {:address_billing {:city ""
                                                                                                                                                                                          :country ""
                                                                                                                                                                                          :extra ""
                                                                                                                                                                                          :house_number ""
                                                                                                                                                                                          :is_user_address_updated false
                                                                                                                                                                                          :mailbox_name ""
                                                                                                                                                                                          :po_box ""
                                                                                                                                                                                          :postal_code ""
                                                                                                                                                                                          :province ""
                                                                                                                                                                                          :street ""}
                                                                                                                                                                        :address_shipping {}
                                                                                                                                                                        :alias {}
                                                                                                                                                                        :allow_bunqto false
                                                                                                                                                                        :amount {}
                                                                                                                                                                        :attachment [{}]
                                                                                                                                                                        :balance_after_mutation {}
                                                                                                                                                                        :batch_id 0
                                                                                                                                                                        :bunqto_expiry ""
                                                                                                                                                                        :bunqto_share_url ""
                                                                                                                                                                        :bunqto_status ""
                                                                                                                                                                        :bunqto_sub_status ""
                                                                                                                                                                        :bunqto_time_responded ""
                                                                                                                                                                        :counterparty_alias {}
                                                                                                                                                                        :created ""
                                                                                                                                                                        :description ""
                                                                                                                                                                        :geolocation {:altitude 0
                                                                                                                                                                                      :latitude 0
                                                                                                                                                                                      :longitude 0
                                                                                                                                                                                      :radius 0}
                                                                                                                                                                        :id 0
                                                                                                                                                                        :merchant_reference ""
                                                                                                                                                                        :monetary_account_id 0
                                                                                                                                                                        :payment_auto_allocate_instance {:created ""
                                                                                                                                                                                                         :error_message []
                                                                                                                                                                                                         :id 0
                                                                                                                                                                                                         :payment_auto_allocate_id 0
                                                                                                                                                                                                         :payment_batch {:payments {:Payment []}}
                                                                                                                                                                                                         :payment_id 0
                                                                                                                                                                                                         :status ""
                                                                                                                                                                                                         :updated ""}
                                                                                                                                                                        :request_reference_split_the_bill [{:id 0
                                                                                                                                                                                                            :type ""}]
                                                                                                                                                                        :scheduled_id 0
                                                                                                                                                                        :sub_type ""
                                                                                                                                                                        :type ""
                                                                                                                                                                        :updated ""}
                                                                                                                                                              :PaymentBatch {}}
                                                                                                                                                     :recurrence_size 0
                                                                                                                                                     :recurrence_unit ""
                                                                                                                                                     :status ""
                                                                                                                                                     :time_end ""
                                                                                                                                                     :time_start ""}}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"payments\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"merchant_reference\": \"\"\n    }\n  ],\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  }\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"payments\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"merchant_reference\": \"\"\n    }\n  ],\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  }\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"payments\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"merchant_reference\": \"\"\n    }\n  ],\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId"

	payload := strings.NewReader("{\n  \"payments\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"merchant_reference\": \"\"\n    }\n  ],\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 2996

{
  "payments": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "allow_bunqto": false,
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "counterparty_alias": {},
      "description": "",
      "merchant_reference": ""
    }
  ],
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"payments\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"merchant_reference\": \"\"\n    }\n  ],\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"payments\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"merchant_reference\": \"\"\n    }\n  ],\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  }\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"payments\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"merchant_reference\": \"\"\n    }\n  ],\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"payments\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"merchant_reference\": \"\"\n    }\n  ],\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  payments: [
    {
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [
            {
              attachment_public_uuid: '',
              content_type: '',
              height: 0,
              width: 0
            }
          ],
          style: '',
          uuid: ''
        },
        bunq_me: {
          name: '',
          service: '',
          type: '',
          value: ''
        },
        country: '',
        display_name: '',
        iban: '',
        is_light: false,
        label_user: {
          avatar: {},
          country: '',
          display_name: '',
          public_nick_name: '',
          uuid: ''
        },
        merchant_category_code: '',
        swift_account_number: '',
        swift_bic: '',
        transferwise_account_number: '',
        transferwise_bank_code: ''
      },
      allow_bunqto: false,
      amount: {
        currency: '',
        value: ''
      },
      attachment: [
        {
          id: 0,
          monetary_account_id: 0
        }
      ],
      counterparty_alias: {},
      description: '',
      merchant_reference: ''
    }
  ],
  schedule: {
    object: {
      Payment: {
        address_billing: {
          city: '',
          country: '',
          extra: '',
          house_number: '',
          is_user_address_updated: false,
          mailbox_name: '',
          po_box: '',
          postal_code: '',
          province: '',
          street: ''
        },
        address_shipping: {},
        alias: {},
        allow_bunqto: false,
        amount: {},
        attachment: [
          {}
        ],
        balance_after_mutation: {},
        batch_id: 0,
        bunqto_expiry: '',
        bunqto_share_url: '',
        bunqto_status: '',
        bunqto_sub_status: '',
        bunqto_time_responded: '',
        counterparty_alias: {},
        created: '',
        description: '',
        geolocation: {
          altitude: 0,
          latitude: 0,
          longitude: 0,
          radius: 0
        },
        id: 0,
        merchant_reference: '',
        monetary_account_id: 0,
        payment_auto_allocate_instance: {
          created: '',
          error_message: [],
          id: 0,
          payment_auto_allocate_id: 0,
          payment_batch: {
            payments: {
              Payment: []
            }
          },
          payment_id: 0,
          status: '',
          updated: ''
        },
        request_reference_split_the_bill: [
          {
            id: 0,
            type: ''
          }
        ],
        scheduled_id: 0,
        sub_type: '',
        type: '',
        updated: ''
      },
      PaymentBatch: {}
    },
    recurrence_size: 0,
    recurrence_unit: '',
    status: '',
    time_end: '',
    time_start: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    payments: [
      {
        alias: {
          avatar: {
            anchor_uuid: '',
            image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
            style: '',
            uuid: ''
          },
          bunq_me: {name: '', service: '', type: '', value: ''},
          country: '',
          display_name: '',
          iban: '',
          is_light: false,
          label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
          merchant_category_code: '',
          swift_account_number: '',
          swift_bic: '',
          transferwise_account_number: '',
          transferwise_bank_code: ''
        },
        allow_bunqto: false,
        amount: {currency: '', value: ''},
        attachment: [{id: 0, monetary_account_id: 0}],
        counterparty_alias: {},
        description: '',
        merchant_reference: ''
      }
    ],
    schedule: {
      object: {
        Payment: {
          address_billing: {
            city: '',
            country: '',
            extra: '',
            house_number: '',
            is_user_address_updated: false,
            mailbox_name: '',
            po_box: '',
            postal_code: '',
            province: '',
            street: ''
          },
          address_shipping: {},
          alias: {},
          allow_bunqto: false,
          amount: {},
          attachment: [{}],
          balance_after_mutation: {},
          batch_id: 0,
          bunqto_expiry: '',
          bunqto_share_url: '',
          bunqto_status: '',
          bunqto_sub_status: '',
          bunqto_time_responded: '',
          counterparty_alias: {},
          created: '',
          description: '',
          geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
          id: 0,
          merchant_reference: '',
          monetary_account_id: 0,
          payment_auto_allocate_instance: {
            created: '',
            error_message: [],
            id: 0,
            payment_auto_allocate_id: 0,
            payment_batch: {payments: {Payment: []}},
            payment_id: 0,
            status: '',
            updated: ''
          },
          request_reference_split_the_bill: [{id: 0, type: ''}],
          scheduled_id: 0,
          sub_type: '',
          type: '',
          updated: ''
        },
        PaymentBatch: {}
      },
      recurrence_size: 0,
      recurrence_unit: '',
      status: '',
      time_end: '',
      time_start: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"payments":[{"alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"allow_bunqto":false,"amount":{"currency":"","value":""},"attachment":[{"id":0,"monetary_account_id":0}],"counterparty_alias":{},"description":"","merchant_reference":""}],"schedule":{"object":{"Payment":{"address_billing":{"city":"","country":"","extra":"","house_number":"","is_user_address_updated":false,"mailbox_name":"","po_box":"","postal_code":"","province":"","street":""},"address_shipping":{},"alias":{},"allow_bunqto":false,"amount":{},"attachment":[{}],"balance_after_mutation":{},"batch_id":0,"bunqto_expiry":"","bunqto_share_url":"","bunqto_status":"","bunqto_sub_status":"","bunqto_time_responded":"","counterparty_alias":{},"created":"","description":"","geolocation":{"altitude":0,"latitude":0,"longitude":0,"radius":0},"id":0,"merchant_reference":"","monetary_account_id":0,"payment_auto_allocate_instance":{"created":"","error_message":[],"id":0,"payment_auto_allocate_id":0,"payment_batch":{"payments":{"Payment":[]}},"payment_id":0,"status":"","updated":""},"request_reference_split_the_bill":[{"id":0,"type":""}],"scheduled_id":0,"sub_type":"","type":"","updated":""},"PaymentBatch":{}},"recurrence_size":0,"recurrence_unit":"","status":"","time_end":"","time_start":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "payments": [\n    {\n      "alias": {\n        "avatar": {\n          "anchor_uuid": "",\n          "image": [\n            {\n              "attachment_public_uuid": "",\n              "content_type": "",\n              "height": 0,\n              "width": 0\n            }\n          ],\n          "style": "",\n          "uuid": ""\n        },\n        "bunq_me": {\n          "name": "",\n          "service": "",\n          "type": "",\n          "value": ""\n        },\n        "country": "",\n        "display_name": "",\n        "iban": "",\n        "is_light": false,\n        "label_user": {\n          "avatar": {},\n          "country": "",\n          "display_name": "",\n          "public_nick_name": "",\n          "uuid": ""\n        },\n        "merchant_category_code": "",\n        "swift_account_number": "",\n        "swift_bic": "",\n        "transferwise_account_number": "",\n        "transferwise_bank_code": ""\n      },\n      "allow_bunqto": false,\n      "amount": {\n        "currency": "",\n        "value": ""\n      },\n      "attachment": [\n        {\n          "id": 0,\n          "monetary_account_id": 0\n        }\n      ],\n      "counterparty_alias": {},\n      "description": "",\n      "merchant_reference": ""\n    }\n  ],\n  "schedule": {\n    "object": {\n      "Payment": {\n        "address_billing": {\n          "city": "",\n          "country": "",\n          "extra": "",\n          "house_number": "",\n          "is_user_address_updated": false,\n          "mailbox_name": "",\n          "po_box": "",\n          "postal_code": "",\n          "province": "",\n          "street": ""\n        },\n        "address_shipping": {},\n        "alias": {},\n        "allow_bunqto": false,\n        "amount": {},\n        "attachment": [\n          {}\n        ],\n        "balance_after_mutation": {},\n        "batch_id": 0,\n        "bunqto_expiry": "",\n        "bunqto_share_url": "",\n        "bunqto_status": "",\n        "bunqto_sub_status": "",\n        "bunqto_time_responded": "",\n        "counterparty_alias": {},\n        "created": "",\n        "description": "",\n        "geolocation": {\n          "altitude": 0,\n          "latitude": 0,\n          "longitude": 0,\n          "radius": 0\n        },\n        "id": 0,\n        "merchant_reference": "",\n        "monetary_account_id": 0,\n        "payment_auto_allocate_instance": {\n          "created": "",\n          "error_message": [],\n          "id": 0,\n          "payment_auto_allocate_id": 0,\n          "payment_batch": {\n            "payments": {\n              "Payment": []\n            }\n          },\n          "payment_id": 0,\n          "status": "",\n          "updated": ""\n        },\n        "request_reference_split_the_bill": [\n          {\n            "id": 0,\n            "type": ""\n          }\n        ],\n        "scheduled_id": 0,\n        "sub_type": "",\n        "type": "",\n        "updated": ""\n      },\n      "PaymentBatch": {}\n    },\n    "recurrence_size": 0,\n    "recurrence_unit": "",\n    "status": "",\n    "time_end": "",\n    "time_start": ""\n  }\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"payments\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"merchant_reference\": \"\"\n    }\n  ],\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  payments: [
    {
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
          style: '',
          uuid: ''
        },
        bunq_me: {name: '', service: '', type: '', value: ''},
        country: '',
        display_name: '',
        iban: '',
        is_light: false,
        label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
        merchant_category_code: '',
        swift_account_number: '',
        swift_bic: '',
        transferwise_account_number: '',
        transferwise_bank_code: ''
      },
      allow_bunqto: false,
      amount: {currency: '', value: ''},
      attachment: [{id: 0, monetary_account_id: 0}],
      counterparty_alias: {},
      description: '',
      merchant_reference: ''
    }
  ],
  schedule: {
    object: {
      Payment: {
        address_billing: {
          city: '',
          country: '',
          extra: '',
          house_number: '',
          is_user_address_updated: false,
          mailbox_name: '',
          po_box: '',
          postal_code: '',
          province: '',
          street: ''
        },
        address_shipping: {},
        alias: {},
        allow_bunqto: false,
        amount: {},
        attachment: [{}],
        balance_after_mutation: {},
        batch_id: 0,
        bunqto_expiry: '',
        bunqto_share_url: '',
        bunqto_status: '',
        bunqto_sub_status: '',
        bunqto_time_responded: '',
        counterparty_alias: {},
        created: '',
        description: '',
        geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
        id: 0,
        merchant_reference: '',
        monetary_account_id: 0,
        payment_auto_allocate_instance: {
          created: '',
          error_message: [],
          id: 0,
          payment_auto_allocate_id: 0,
          payment_batch: {payments: {Payment: []}},
          payment_id: 0,
          status: '',
          updated: ''
        },
        request_reference_split_the_bill: [{id: 0, type: ''}],
        scheduled_id: 0,
        sub_type: '',
        type: '',
        updated: ''
      },
      PaymentBatch: {}
    },
    recurrence_size: 0,
    recurrence_unit: '',
    status: '',
    time_end: '',
    time_start: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    payments: [
      {
        alias: {
          avatar: {
            anchor_uuid: '',
            image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
            style: '',
            uuid: ''
          },
          bunq_me: {name: '', service: '', type: '', value: ''},
          country: '',
          display_name: '',
          iban: '',
          is_light: false,
          label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
          merchant_category_code: '',
          swift_account_number: '',
          swift_bic: '',
          transferwise_account_number: '',
          transferwise_bank_code: ''
        },
        allow_bunqto: false,
        amount: {currency: '', value: ''},
        attachment: [{id: 0, monetary_account_id: 0}],
        counterparty_alias: {},
        description: '',
        merchant_reference: ''
      }
    ],
    schedule: {
      object: {
        Payment: {
          address_billing: {
            city: '',
            country: '',
            extra: '',
            house_number: '',
            is_user_address_updated: false,
            mailbox_name: '',
            po_box: '',
            postal_code: '',
            province: '',
            street: ''
          },
          address_shipping: {},
          alias: {},
          allow_bunqto: false,
          amount: {},
          attachment: [{}],
          balance_after_mutation: {},
          batch_id: 0,
          bunqto_expiry: '',
          bunqto_share_url: '',
          bunqto_status: '',
          bunqto_sub_status: '',
          bunqto_time_responded: '',
          counterparty_alias: {},
          created: '',
          description: '',
          geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
          id: 0,
          merchant_reference: '',
          monetary_account_id: 0,
          payment_auto_allocate_instance: {
            created: '',
            error_message: [],
            id: 0,
            payment_auto_allocate_id: 0,
            payment_batch: {payments: {Payment: []}},
            payment_id: 0,
            status: '',
            updated: ''
          },
          request_reference_split_the_bill: [{id: 0, type: ''}],
          scheduled_id: 0,
          sub_type: '',
          type: '',
          updated: ''
        },
        PaymentBatch: {}
      },
      recurrence_size: 0,
      recurrence_unit: '',
      status: '',
      time_end: '',
      time_start: ''
    }
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  payments: [
    {
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [
            {
              attachment_public_uuid: '',
              content_type: '',
              height: 0,
              width: 0
            }
          ],
          style: '',
          uuid: ''
        },
        bunq_me: {
          name: '',
          service: '',
          type: '',
          value: ''
        },
        country: '',
        display_name: '',
        iban: '',
        is_light: false,
        label_user: {
          avatar: {},
          country: '',
          display_name: '',
          public_nick_name: '',
          uuid: ''
        },
        merchant_category_code: '',
        swift_account_number: '',
        swift_bic: '',
        transferwise_account_number: '',
        transferwise_bank_code: ''
      },
      allow_bunqto: false,
      amount: {
        currency: '',
        value: ''
      },
      attachment: [
        {
          id: 0,
          monetary_account_id: 0
        }
      ],
      counterparty_alias: {},
      description: '',
      merchant_reference: ''
    }
  ],
  schedule: {
    object: {
      Payment: {
        address_billing: {
          city: '',
          country: '',
          extra: '',
          house_number: '',
          is_user_address_updated: false,
          mailbox_name: '',
          po_box: '',
          postal_code: '',
          province: '',
          street: ''
        },
        address_shipping: {},
        alias: {},
        allow_bunqto: false,
        amount: {},
        attachment: [
          {}
        ],
        balance_after_mutation: {},
        batch_id: 0,
        bunqto_expiry: '',
        bunqto_share_url: '',
        bunqto_status: '',
        bunqto_sub_status: '',
        bunqto_time_responded: '',
        counterparty_alias: {},
        created: '',
        description: '',
        geolocation: {
          altitude: 0,
          latitude: 0,
          longitude: 0,
          radius: 0
        },
        id: 0,
        merchant_reference: '',
        monetary_account_id: 0,
        payment_auto_allocate_instance: {
          created: '',
          error_message: [],
          id: 0,
          payment_auto_allocate_id: 0,
          payment_batch: {
            payments: {
              Payment: []
            }
          },
          payment_id: 0,
          status: '',
          updated: ''
        },
        request_reference_split_the_bill: [
          {
            id: 0,
            type: ''
          }
        ],
        scheduled_id: 0,
        sub_type: '',
        type: '',
        updated: ''
      },
      PaymentBatch: {}
    },
    recurrence_size: 0,
    recurrence_unit: '',
    status: '',
    time_end: '',
    time_start: ''
  }
});

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}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    payments: [
      {
        alias: {
          avatar: {
            anchor_uuid: '',
            image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
            style: '',
            uuid: ''
          },
          bunq_me: {name: '', service: '', type: '', value: ''},
          country: '',
          display_name: '',
          iban: '',
          is_light: false,
          label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
          merchant_category_code: '',
          swift_account_number: '',
          swift_bic: '',
          transferwise_account_number: '',
          transferwise_bank_code: ''
        },
        allow_bunqto: false,
        amount: {currency: '', value: ''},
        attachment: [{id: 0, monetary_account_id: 0}],
        counterparty_alias: {},
        description: '',
        merchant_reference: ''
      }
    ],
    schedule: {
      object: {
        Payment: {
          address_billing: {
            city: '',
            country: '',
            extra: '',
            house_number: '',
            is_user_address_updated: false,
            mailbox_name: '',
            po_box: '',
            postal_code: '',
            province: '',
            street: ''
          },
          address_shipping: {},
          alias: {},
          allow_bunqto: false,
          amount: {},
          attachment: [{}],
          balance_after_mutation: {},
          batch_id: 0,
          bunqto_expiry: '',
          bunqto_share_url: '',
          bunqto_status: '',
          bunqto_sub_status: '',
          bunqto_time_responded: '',
          counterparty_alias: {},
          created: '',
          description: '',
          geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
          id: 0,
          merchant_reference: '',
          monetary_account_id: 0,
          payment_auto_allocate_instance: {
            created: '',
            error_message: [],
            id: 0,
            payment_auto_allocate_id: 0,
            payment_batch: {payments: {Payment: []}},
            payment_id: 0,
            status: '',
            updated: ''
          },
          request_reference_split_the_bill: [{id: 0, type: ''}],
          scheduled_id: 0,
          sub_type: '',
          type: '',
          updated: ''
        },
        PaymentBatch: {}
      },
      recurrence_size: 0,
      recurrence_unit: '',
      status: '',
      time_end: '',
      time_start: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"payments":[{"alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"allow_bunqto":false,"amount":{"currency":"","value":""},"attachment":[{"id":0,"monetary_account_id":0}],"counterparty_alias":{},"description":"","merchant_reference":""}],"schedule":{"object":{"Payment":{"address_billing":{"city":"","country":"","extra":"","house_number":"","is_user_address_updated":false,"mailbox_name":"","po_box":"","postal_code":"","province":"","street":""},"address_shipping":{},"alias":{},"allow_bunqto":false,"amount":{},"attachment":[{}],"balance_after_mutation":{},"batch_id":0,"bunqto_expiry":"","bunqto_share_url":"","bunqto_status":"","bunqto_sub_status":"","bunqto_time_responded":"","counterparty_alias":{},"created":"","description":"","geolocation":{"altitude":0,"latitude":0,"longitude":0,"radius":0},"id":0,"merchant_reference":"","monetary_account_id":0,"payment_auto_allocate_instance":{"created":"","error_message":[],"id":0,"payment_auto_allocate_id":0,"payment_batch":{"payments":{"Payment":[]}},"payment_id":0,"status":"","updated":""},"request_reference_split_the_bill":[{"id":0,"type":""}],"scheduled_id":0,"sub_type":"","type":"","updated":""},"PaymentBatch":{}},"recurrence_size":0,"recurrence_unit":"","status":"","time_end":"","time_start":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"payments": @[ @{ @"alias": @{ @"avatar": @{ @"anchor_uuid": @"", @"image": @[ @{ @"attachment_public_uuid": @"", @"content_type": @"", @"height": @0, @"width": @0 } ], @"style": @"", @"uuid": @"" }, @"bunq_me": @{ @"name": @"", @"service": @"", @"type": @"", @"value": @"" }, @"country": @"", @"display_name": @"", @"iban": @"", @"is_light": @NO, @"label_user": @{ @"avatar": @{  }, @"country": @"", @"display_name": @"", @"public_nick_name": @"", @"uuid": @"" }, @"merchant_category_code": @"", @"swift_account_number": @"", @"swift_bic": @"", @"transferwise_account_number": @"", @"transferwise_bank_code": @"" }, @"allow_bunqto": @NO, @"amount": @{ @"currency": @"", @"value": @"" }, @"attachment": @[ @{ @"id": @0, @"monetary_account_id": @0 } ], @"counterparty_alias": @{  }, @"description": @"", @"merchant_reference": @"" } ],
                              @"schedule": @{ @"object": @{ @"Payment": @{ @"address_billing": @{ @"city": @"", @"country": @"", @"extra": @"", @"house_number": @"", @"is_user_address_updated": @NO, @"mailbox_name": @"", @"po_box": @"", @"postal_code": @"", @"province": @"", @"street": @"" }, @"address_shipping": @{  }, @"alias": @{  }, @"allow_bunqto": @NO, @"amount": @{  }, @"attachment": @[ @{  } ], @"balance_after_mutation": @{  }, @"batch_id": @0, @"bunqto_expiry": @"", @"bunqto_share_url": @"", @"bunqto_status": @"", @"bunqto_sub_status": @"", @"bunqto_time_responded": @"", @"counterparty_alias": @{  }, @"created": @"", @"description": @"", @"geolocation": @{ @"altitude": @0, @"latitude": @0, @"longitude": @0, @"radius": @0 }, @"id": @0, @"merchant_reference": @"", @"monetary_account_id": @0, @"payment_auto_allocate_instance": @{ @"created": @"", @"error_message": @[  ], @"id": @0, @"payment_auto_allocate_id": @0, @"payment_batch": @{ @"payments": @{ @"Payment": @[  ] } }, @"payment_id": @0, @"status": @"", @"updated": @"" }, @"request_reference_split_the_bill": @[ @{ @"id": @0, @"type": @"" } ], @"scheduled_id": @0, @"sub_type": @"", @"type": @"", @"updated": @"" }, @"PaymentBatch": @{  } }, @"recurrence_size": @0, @"recurrence_unit": @"", @"status": @"", @"time_end": @"", @"time_start": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"payments\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"merchant_reference\": \"\"\n    }\n  ],\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'payments' => [
        [
                'alias' => [
                                'avatar' => [
                                                                'anchor_uuid' => '',
                                                                'image' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'attachment_public_uuid' => '',
                                                                                                                                                                                                                                                                'content_type' => '',
                                                                                                                                                                                                                                                                'height' => 0,
                                                                                                                                                                                                                                                                'width' => 0
                                                                                                                                ]
                                                                ],
                                                                'style' => '',
                                                                'uuid' => ''
                                ],
                                'bunq_me' => [
                                                                'name' => '',
                                                                'service' => '',
                                                                'type' => '',
                                                                'value' => ''
                                ],
                                'country' => '',
                                'display_name' => '',
                                'iban' => '',
                                'is_light' => null,
                                'label_user' => [
                                                                'avatar' => [
                                                                                                                                
                                                                ],
                                                                'country' => '',
                                                                'display_name' => '',
                                                                'public_nick_name' => '',
                                                                'uuid' => ''
                                ],
                                'merchant_category_code' => '',
                                'swift_account_number' => '',
                                'swift_bic' => '',
                                'transferwise_account_number' => '',
                                'transferwise_bank_code' => ''
                ],
                'allow_bunqto' => null,
                'amount' => [
                                'currency' => '',
                                'value' => ''
                ],
                'attachment' => [
                                [
                                                                'id' => 0,
                                                                'monetary_account_id' => 0
                                ]
                ],
                'counterparty_alias' => [
                                
                ],
                'description' => '',
                'merchant_reference' => ''
        ]
    ],
    'schedule' => [
        'object' => [
                'Payment' => [
                                'address_billing' => [
                                                                'city' => '',
                                                                'country' => '',
                                                                'extra' => '',
                                                                'house_number' => '',
                                                                'is_user_address_updated' => null,
                                                                'mailbox_name' => '',
                                                                'po_box' => '',
                                                                'postal_code' => '',
                                                                'province' => '',
                                                                'street' => ''
                                ],
                                'address_shipping' => [
                                                                
                                ],
                                'alias' => [
                                                                
                                ],
                                'allow_bunqto' => null,
                                'amount' => [
                                                                
                                ],
                                'attachment' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'balance_after_mutation' => [
                                                                
                                ],
                                'batch_id' => 0,
                                'bunqto_expiry' => '',
                                'bunqto_share_url' => '',
                                'bunqto_status' => '',
                                'bunqto_sub_status' => '',
                                'bunqto_time_responded' => '',
                                'counterparty_alias' => [
                                                                
                                ],
                                'created' => '',
                                'description' => '',
                                'geolocation' => [
                                                                'altitude' => 0,
                                                                'latitude' => 0,
                                                                'longitude' => 0,
                                                                'radius' => 0
                                ],
                                'id' => 0,
                                'merchant_reference' => '',
                                'monetary_account_id' => 0,
                                'payment_auto_allocate_instance' => [
                                                                'created' => '',
                                                                'error_message' => [
                                                                                                                                
                                                                ],
                                                                'id' => 0,
                                                                'payment_auto_allocate_id' => 0,
                                                                'payment_batch' => [
                                                                                                                                'payments' => [
                                                                                                                                                                                                                                                                'Payment' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ]
                                                                                                                                ]
                                                                ],
                                                                'payment_id' => 0,
                                                                'status' => '',
                                                                'updated' => ''
                                ],
                                'request_reference_split_the_bill' => [
                                                                [
                                                                                                                                'id' => 0,
                                                                                                                                'type' => ''
                                                                ]
                                ],
                                'scheduled_id' => 0,
                                'sub_type' => '',
                                'type' => '',
                                'updated' => ''
                ],
                'PaymentBatch' => [
                                
                ]
        ],
        'recurrence_size' => 0,
        'recurrence_unit' => '',
        'status' => '',
        'time_end' => '',
        'time_start' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId', [
  'body' => '{
  "payments": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "allow_bunqto": false,
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "counterparty_alias": {},
      "description": "",
      "merchant_reference": ""
    }
  ],
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'payments' => [
    [
        'alias' => [
                'avatar' => [
                                'anchor_uuid' => '',
                                'image' => [
                                                                [
                                                                                                                                'attachment_public_uuid' => '',
                                                                                                                                'content_type' => '',
                                                                                                                                'height' => 0,
                                                                                                                                'width' => 0
                                                                ]
                                ],
                                'style' => '',
                                'uuid' => ''
                ],
                'bunq_me' => [
                                'name' => '',
                                'service' => '',
                                'type' => '',
                                'value' => ''
                ],
                'country' => '',
                'display_name' => '',
                'iban' => '',
                'is_light' => null,
                'label_user' => [
                                'avatar' => [
                                                                
                                ],
                                'country' => '',
                                'display_name' => '',
                                'public_nick_name' => '',
                                'uuid' => ''
                ],
                'merchant_category_code' => '',
                'swift_account_number' => '',
                'swift_bic' => '',
                'transferwise_account_number' => '',
                'transferwise_bank_code' => ''
        ],
        'allow_bunqto' => null,
        'amount' => [
                'currency' => '',
                'value' => ''
        ],
        'attachment' => [
                [
                                'id' => 0,
                                'monetary_account_id' => 0
                ]
        ],
        'counterparty_alias' => [
                
        ],
        'description' => '',
        'merchant_reference' => ''
    ]
  ],
  'schedule' => [
    'object' => [
        'Payment' => [
                'address_billing' => [
                                'city' => '',
                                'country' => '',
                                'extra' => '',
                                'house_number' => '',
                                'is_user_address_updated' => null,
                                'mailbox_name' => '',
                                'po_box' => '',
                                'postal_code' => '',
                                'province' => '',
                                'street' => ''
                ],
                'address_shipping' => [
                                
                ],
                'alias' => [
                                
                ],
                'allow_bunqto' => null,
                'amount' => [
                                
                ],
                'attachment' => [
                                [
                                                                
                                ]
                ],
                'balance_after_mutation' => [
                                
                ],
                'batch_id' => 0,
                'bunqto_expiry' => '',
                'bunqto_share_url' => '',
                'bunqto_status' => '',
                'bunqto_sub_status' => '',
                'bunqto_time_responded' => '',
                'counterparty_alias' => [
                                
                ],
                'created' => '',
                'description' => '',
                'geolocation' => [
                                'altitude' => 0,
                                'latitude' => 0,
                                'longitude' => 0,
                                'radius' => 0
                ],
                'id' => 0,
                'merchant_reference' => '',
                'monetary_account_id' => 0,
                'payment_auto_allocate_instance' => [
                                'created' => '',
                                'error_message' => [
                                                                
                                ],
                                'id' => 0,
                                'payment_auto_allocate_id' => 0,
                                'payment_batch' => [
                                                                'payments' => [
                                                                                                                                'Payment' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'payment_id' => 0,
                                'status' => '',
                                'updated' => ''
                ],
                'request_reference_split_the_bill' => [
                                [
                                                                'id' => 0,
                                                                'type' => ''
                                ]
                ],
                'scheduled_id' => 0,
                'sub_type' => '',
                'type' => '',
                'updated' => ''
        ],
        'PaymentBatch' => [
                
        ]
    ],
    'recurrence_size' => 0,
    'recurrence_unit' => '',
    'status' => '',
    'time_end' => '',
    'time_start' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'payments' => [
    [
        'alias' => [
                'avatar' => [
                                'anchor_uuid' => '',
                                'image' => [
                                                                [
                                                                                                                                'attachment_public_uuid' => '',
                                                                                                                                'content_type' => '',
                                                                                                                                'height' => 0,
                                                                                                                                'width' => 0
                                                                ]
                                ],
                                'style' => '',
                                'uuid' => ''
                ],
                'bunq_me' => [
                                'name' => '',
                                'service' => '',
                                'type' => '',
                                'value' => ''
                ],
                'country' => '',
                'display_name' => '',
                'iban' => '',
                'is_light' => null,
                'label_user' => [
                                'avatar' => [
                                                                
                                ],
                                'country' => '',
                                'display_name' => '',
                                'public_nick_name' => '',
                                'uuid' => ''
                ],
                'merchant_category_code' => '',
                'swift_account_number' => '',
                'swift_bic' => '',
                'transferwise_account_number' => '',
                'transferwise_bank_code' => ''
        ],
        'allow_bunqto' => null,
        'amount' => [
                'currency' => '',
                'value' => ''
        ],
        'attachment' => [
                [
                                'id' => 0,
                                'monetary_account_id' => 0
                ]
        ],
        'counterparty_alias' => [
                
        ],
        'description' => '',
        'merchant_reference' => ''
    ]
  ],
  'schedule' => [
    'object' => [
        'Payment' => [
                'address_billing' => [
                                'city' => '',
                                'country' => '',
                                'extra' => '',
                                'house_number' => '',
                                'is_user_address_updated' => null,
                                'mailbox_name' => '',
                                'po_box' => '',
                                'postal_code' => '',
                                'province' => '',
                                'street' => ''
                ],
                'address_shipping' => [
                                
                ],
                'alias' => [
                                
                ],
                'allow_bunqto' => null,
                'amount' => [
                                
                ],
                'attachment' => [
                                [
                                                                
                                ]
                ],
                'balance_after_mutation' => [
                                
                ],
                'batch_id' => 0,
                'bunqto_expiry' => '',
                'bunqto_share_url' => '',
                'bunqto_status' => '',
                'bunqto_sub_status' => '',
                'bunqto_time_responded' => '',
                'counterparty_alias' => [
                                
                ],
                'created' => '',
                'description' => '',
                'geolocation' => [
                                'altitude' => 0,
                                'latitude' => 0,
                                'longitude' => 0,
                                'radius' => 0
                ],
                'id' => 0,
                'merchant_reference' => '',
                'monetary_account_id' => 0,
                'payment_auto_allocate_instance' => [
                                'created' => '',
                                'error_message' => [
                                                                
                                ],
                                'id' => 0,
                                'payment_auto_allocate_id' => 0,
                                'payment_batch' => [
                                                                'payments' => [
                                                                                                                                'Payment' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'payment_id' => 0,
                                'status' => '',
                                'updated' => ''
                ],
                'request_reference_split_the_bill' => [
                                [
                                                                'id' => 0,
                                                                'type' => ''
                                ]
                ],
                'scheduled_id' => 0,
                'sub_type' => '',
                'type' => '',
                'updated' => ''
        ],
        'PaymentBatch' => [
                
        ]
    ],
    'recurrence_size' => 0,
    'recurrence_unit' => '',
    'status' => '',
    'time_end' => '',
    'time_start' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "payments": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "allow_bunqto": false,
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "counterparty_alias": {},
      "description": "",
      "merchant_reference": ""
    }
  ],
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  }
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "payments": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "allow_bunqto": false,
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "counterparty_alias": {},
      "description": "",
      "merchant_reference": ""
    }
  ],
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"payments\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"merchant_reference\": \"\"\n    }\n  ],\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  }\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId"

payload = {
    "payments": [
        {
            "alias": {
                "avatar": {
                    "anchor_uuid": "",
                    "image": [
                        {
                            "attachment_public_uuid": "",
                            "content_type": "",
                            "height": 0,
                            "width": 0
                        }
                    ],
                    "style": "",
                    "uuid": ""
                },
                "bunq_me": {
                    "name": "",
                    "service": "",
                    "type": "",
                    "value": ""
                },
                "country": "",
                "display_name": "",
                "iban": "",
                "is_light": False,
                "label_user": {
                    "avatar": {},
                    "country": "",
                    "display_name": "",
                    "public_nick_name": "",
                    "uuid": ""
                },
                "merchant_category_code": "",
                "swift_account_number": "",
                "swift_bic": "",
                "transferwise_account_number": "",
                "transferwise_bank_code": ""
            },
            "allow_bunqto": False,
            "amount": {
                "currency": "",
                "value": ""
            },
            "attachment": [
                {
                    "id": 0,
                    "monetary_account_id": 0
                }
            ],
            "counterparty_alias": {},
            "description": "",
            "merchant_reference": ""
        }
    ],
    "schedule": {
        "object": {
            "Payment": {
                "address_billing": {
                    "city": "",
                    "country": "",
                    "extra": "",
                    "house_number": "",
                    "is_user_address_updated": False,
                    "mailbox_name": "",
                    "po_box": "",
                    "postal_code": "",
                    "province": "",
                    "street": ""
                },
                "address_shipping": {},
                "alias": {},
                "allow_bunqto": False,
                "amount": {},
                "attachment": [{}],
                "balance_after_mutation": {},
                "batch_id": 0,
                "bunqto_expiry": "",
                "bunqto_share_url": "",
                "bunqto_status": "",
                "bunqto_sub_status": "",
                "bunqto_time_responded": "",
                "counterparty_alias": {},
                "created": "",
                "description": "",
                "geolocation": {
                    "altitude": 0,
                    "latitude": 0,
                    "longitude": 0,
                    "radius": 0
                },
                "id": 0,
                "merchant_reference": "",
                "monetary_account_id": 0,
                "payment_auto_allocate_instance": {
                    "created": "",
                    "error_message": [],
                    "id": 0,
                    "payment_auto_allocate_id": 0,
                    "payment_batch": { "payments": { "Payment": [] } },
                    "payment_id": 0,
                    "status": "",
                    "updated": ""
                },
                "request_reference_split_the_bill": [
                    {
                        "id": 0,
                        "type": ""
                    }
                ],
                "scheduled_id": 0,
                "sub_type": "",
                "type": "",
                "updated": ""
            },
            "PaymentBatch": {}
        },
        "recurrence_size": 0,
        "recurrence_unit": "",
        "status": "",
        "time_end": "",
        "time_start": ""
    }
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId"

payload <- "{\n  \"payments\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"merchant_reference\": \"\"\n    }\n  ],\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"payments\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"merchant_reference\": \"\"\n    }\n  ],\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  }\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"payments\": [\n    {\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"counterparty_alias\": {},\n      \"description\": \"\",\n      \"merchant_reference\": \"\"\n    }\n  ],\n  \"schedule\": {\n    \"object\": {\n      \"Payment\": {\n        \"address_billing\": {\n          \"city\": \"\",\n          \"country\": \"\",\n          \"extra\": \"\",\n          \"house_number\": \"\",\n          \"is_user_address_updated\": false,\n          \"mailbox_name\": \"\",\n          \"po_box\": \"\",\n          \"postal_code\": \"\",\n          \"province\": \"\",\n          \"street\": \"\"\n        },\n        \"address_shipping\": {},\n        \"alias\": {},\n        \"allow_bunqto\": false,\n        \"amount\": {},\n        \"attachment\": [\n          {}\n        ],\n        \"balance_after_mutation\": {},\n        \"batch_id\": 0,\n        \"bunqto_expiry\": \"\",\n        \"bunqto_share_url\": \"\",\n        \"bunqto_status\": \"\",\n        \"bunqto_sub_status\": \"\",\n        \"bunqto_time_responded\": \"\",\n        \"counterparty_alias\": {},\n        \"created\": \"\",\n        \"description\": \"\",\n        \"geolocation\": {\n          \"altitude\": 0,\n          \"latitude\": 0,\n          \"longitude\": 0,\n          \"radius\": 0\n        },\n        \"id\": 0,\n        \"merchant_reference\": \"\",\n        \"monetary_account_id\": 0,\n        \"payment_auto_allocate_instance\": {\n          \"created\": \"\",\n          \"error_message\": [],\n          \"id\": 0,\n          \"payment_auto_allocate_id\": 0,\n          \"payment_batch\": {\n            \"payments\": {\n              \"Payment\": []\n            }\n          },\n          \"payment_id\": 0,\n          \"status\": \"\",\n          \"updated\": \"\"\n        },\n        \"request_reference_split_the_bill\": [\n          {\n            \"id\": 0,\n            \"type\": \"\"\n          }\n        ],\n        \"scheduled_id\": 0,\n        \"sub_type\": \"\",\n        \"type\": \"\",\n        \"updated\": \"\"\n      },\n      \"PaymentBatch\": {}\n    },\n    \"recurrence_size\": 0,\n    \"recurrence_unit\": \"\",\n    \"status\": \"\",\n    \"time_end\": \"\",\n    \"time_start\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId";

    let payload = json!({
        "payments": (
            json!({
                "alias": json!({
                    "avatar": json!({
                        "anchor_uuid": "",
                        "image": (
                            json!({
                                "attachment_public_uuid": "",
                                "content_type": "",
                                "height": 0,
                                "width": 0
                            })
                        ),
                        "style": "",
                        "uuid": ""
                    }),
                    "bunq_me": json!({
                        "name": "",
                        "service": "",
                        "type": "",
                        "value": ""
                    }),
                    "country": "",
                    "display_name": "",
                    "iban": "",
                    "is_light": false,
                    "label_user": json!({
                        "avatar": json!({}),
                        "country": "",
                        "display_name": "",
                        "public_nick_name": "",
                        "uuid": ""
                    }),
                    "merchant_category_code": "",
                    "swift_account_number": "",
                    "swift_bic": "",
                    "transferwise_account_number": "",
                    "transferwise_bank_code": ""
                }),
                "allow_bunqto": false,
                "amount": json!({
                    "currency": "",
                    "value": ""
                }),
                "attachment": (
                    json!({
                        "id": 0,
                        "monetary_account_id": 0
                    })
                ),
                "counterparty_alias": json!({}),
                "description": "",
                "merchant_reference": ""
            })
        ),
        "schedule": json!({
            "object": json!({
                "Payment": json!({
                    "address_billing": json!({
                        "city": "",
                        "country": "",
                        "extra": "",
                        "house_number": "",
                        "is_user_address_updated": false,
                        "mailbox_name": "",
                        "po_box": "",
                        "postal_code": "",
                        "province": "",
                        "street": ""
                    }),
                    "address_shipping": json!({}),
                    "alias": json!({}),
                    "allow_bunqto": false,
                    "amount": json!({}),
                    "attachment": (json!({})),
                    "balance_after_mutation": json!({}),
                    "batch_id": 0,
                    "bunqto_expiry": "",
                    "bunqto_share_url": "",
                    "bunqto_status": "",
                    "bunqto_sub_status": "",
                    "bunqto_time_responded": "",
                    "counterparty_alias": json!({}),
                    "created": "",
                    "description": "",
                    "geolocation": json!({
                        "altitude": 0,
                        "latitude": 0,
                        "longitude": 0,
                        "radius": 0
                    }),
                    "id": 0,
                    "merchant_reference": "",
                    "monetary_account_id": 0,
                    "payment_auto_allocate_instance": json!({
                        "created": "",
                        "error_message": (),
                        "id": 0,
                        "payment_auto_allocate_id": 0,
                        "payment_batch": json!({"payments": json!({"Payment": ()})}),
                        "payment_id": 0,
                        "status": "",
                        "updated": ""
                    }),
                    "request_reference_split_the_bill": (
                        json!({
                            "id": 0,
                            "type": ""
                        })
                    ),
                    "scheduled_id": 0,
                    "sub_type": "",
                    "type": "",
                    "updated": ""
                }),
                "PaymentBatch": json!({})
            }),
            "recurrence_size": 0,
            "recurrence_unit": "",
            "status": "",
            "time_end": "",
            "time_start": ""
        })
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "payments": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "allow_bunqto": false,
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "counterparty_alias": {},
      "description": "",
      "merchant_reference": ""
    }
  ],
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  }
}'
echo '{
  "payments": [
    {
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "allow_bunqto": false,
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "counterparty_alias": {},
      "description": "",
      "merchant_reference": ""
    }
  ],
  "schedule": {
    "object": {
      "Payment": {
        "address_billing": {
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        },
        "address_shipping": {},
        "alias": {},
        "allow_bunqto": false,
        "amount": {},
        "attachment": [
          {}
        ],
        "balance_after_mutation": {},
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": {},
        "created": "",
        "description": "",
        "geolocation": {
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        },
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": {
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": {
            "payments": {
              "Payment": []
            }
          },
          "payment_id": 0,
          "status": "",
          "updated": ""
        },
        "request_reference_split_the_bill": [
          {
            "id": 0,
            "type": ""
          }
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      },
      "PaymentBatch": {}
    },
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  }
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "payments": [\n    {\n      "alias": {\n        "avatar": {\n          "anchor_uuid": "",\n          "image": [\n            {\n              "attachment_public_uuid": "",\n              "content_type": "",\n              "height": 0,\n              "width": 0\n            }\n          ],\n          "style": "",\n          "uuid": ""\n        },\n        "bunq_me": {\n          "name": "",\n          "service": "",\n          "type": "",\n          "value": ""\n        },\n        "country": "",\n        "display_name": "",\n        "iban": "",\n        "is_light": false,\n        "label_user": {\n          "avatar": {},\n          "country": "",\n          "display_name": "",\n          "public_nick_name": "",\n          "uuid": ""\n        },\n        "merchant_category_code": "",\n        "swift_account_number": "",\n        "swift_bic": "",\n        "transferwise_account_number": "",\n        "transferwise_bank_code": ""\n      },\n      "allow_bunqto": false,\n      "amount": {\n        "currency": "",\n        "value": ""\n      },\n      "attachment": [\n        {\n          "id": 0,\n          "monetary_account_id": 0\n        }\n      ],\n      "counterparty_alias": {},\n      "description": "",\n      "merchant_reference": ""\n    }\n  ],\n  "schedule": {\n    "object": {\n      "Payment": {\n        "address_billing": {\n          "city": "",\n          "country": "",\n          "extra": "",\n          "house_number": "",\n          "is_user_address_updated": false,\n          "mailbox_name": "",\n          "po_box": "",\n          "postal_code": "",\n          "province": "",\n          "street": ""\n        },\n        "address_shipping": {},\n        "alias": {},\n        "allow_bunqto": false,\n        "amount": {},\n        "attachment": [\n          {}\n        ],\n        "balance_after_mutation": {},\n        "batch_id": 0,\n        "bunqto_expiry": "",\n        "bunqto_share_url": "",\n        "bunqto_status": "",\n        "bunqto_sub_status": "",\n        "bunqto_time_responded": "",\n        "counterparty_alias": {},\n        "created": "",\n        "description": "",\n        "geolocation": {\n          "altitude": 0,\n          "latitude": 0,\n          "longitude": 0,\n          "radius": 0\n        },\n        "id": 0,\n        "merchant_reference": "",\n        "monetary_account_id": 0,\n        "payment_auto_allocate_instance": {\n          "created": "",\n          "error_message": [],\n          "id": 0,\n          "payment_auto_allocate_id": 0,\n          "payment_batch": {\n            "payments": {\n              "Payment": []\n            }\n          },\n          "payment_id": 0,\n          "status": "",\n          "updated": ""\n        },\n        "request_reference_split_the_bill": [\n          {\n            "id": 0,\n            "type": ""\n          }\n        ],\n        "scheduled_id": 0,\n        "sub_type": "",\n        "type": "",\n        "updated": ""\n      },\n      "PaymentBatch": {}\n    },\n    "recurrence_size": 0,\n    "recurrence_unit": "",\n    "status": "",\n    "time_end": "",\n    "time_start": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "payments": [
    [
      "alias": [
        "avatar": [
          "anchor_uuid": "",
          "image": [
            [
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            ]
          ],
          "style": "",
          "uuid": ""
        ],
        "bunq_me": [
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        ],
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": [
          "avatar": [],
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        ],
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      ],
      "allow_bunqto": false,
      "amount": [
        "currency": "",
        "value": ""
      ],
      "attachment": [
        [
          "id": 0,
          "monetary_account_id": 0
        ]
      ],
      "counterparty_alias": [],
      "description": "",
      "merchant_reference": ""
    ]
  ],
  "schedule": [
    "object": [
      "Payment": [
        "address_billing": [
          "city": "",
          "country": "",
          "extra": "",
          "house_number": "",
          "is_user_address_updated": false,
          "mailbox_name": "",
          "po_box": "",
          "postal_code": "",
          "province": "",
          "street": ""
        ],
        "address_shipping": [],
        "alias": [],
        "allow_bunqto": false,
        "amount": [],
        "attachment": [[]],
        "balance_after_mutation": [],
        "batch_id": 0,
        "bunqto_expiry": "",
        "bunqto_share_url": "",
        "bunqto_status": "",
        "bunqto_sub_status": "",
        "bunqto_time_responded": "",
        "counterparty_alias": [],
        "created": "",
        "description": "",
        "geolocation": [
          "altitude": 0,
          "latitude": 0,
          "longitude": 0,
          "radius": 0
        ],
        "id": 0,
        "merchant_reference": "",
        "monetary_account_id": 0,
        "payment_auto_allocate_instance": [
          "created": "",
          "error_message": [],
          "id": 0,
          "payment_auto_allocate_id": 0,
          "payment_batch": ["payments": ["Payment": []]],
          "payment_id": 0,
          "status": "",
          "updated": ""
        ],
        "request_reference_split_the_bill": [
          [
            "id": 0,
            "type": ""
          ]
        ],
        "scheduled_id": 0,
        "sub_type": "",
        "type": "",
        "updated": ""
      ],
      "PaymentBatch": []
    ],
    "recurrence_size": 0,
    "recurrence_unit": "",
    "status": "",
    "time_end": "",
    "time_start": ""
  ]
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/schedule-payment-batch/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_ServerError
{{baseUrl}}/server-error
HEADERS

User-Agent
X-Bunq-Client-Authentication
BODY json

{}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/server-error");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/server-error" {:headers {:user-agent ""
                                                                   :x-bunq-client-authentication ""}
                                                         :content-type :json})
require "http/client"

url = "{{baseUrl}}/server-error"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/server-error"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/server-error");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/server-error"

	payload := strings.NewReader("{}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/server-error HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 2

{}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/server-error")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/server-error"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/server-error")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/server-error")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{}")
  .asString();
const data = JSON.stringify({});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/server-error');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/server-error',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/server-error';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/server-error',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{}")
val request = Request.Builder()
  .url("{{baseUrl}}/server-error")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/server-error',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/server-error',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/server-error');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/server-error',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/server-error';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{  };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/server-error"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/server-error" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/server-error",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/server-error', [
  'body' => '{}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/server-error');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  
]));
$request->setRequestUrl('{{baseUrl}}/server-error');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/server-error' -Method POST -Headers $headers -ContentType 'application/json' -Body '{}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/server-error' -Method POST -Headers $headers -ContentType 'application/json' -Body '{}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/server-error", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/server-error"

payload = {}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/server-error"

payload <- "{}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/server-error")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/server-error') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/server-error";

    let payload = json!({});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/server-error \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{}'
echo '{}' |  \
  http POST {{baseUrl}}/server-error \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{}' \
  --output-document \
  - {{baseUrl}}/server-error
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/server-error")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_ServerPublicKey_for_Installation
{{baseUrl}}/installation/:installationID/server-public-key
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

installationID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/installation/:installationID/server-public-key");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/installation/:installationID/server-public-key" {:headers {:user-agent ""
                                                                                                    :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/installation/:installationID/server-public-key"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/installation/:installationID/server-public-key"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/installation/:installationID/server-public-key");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/installation/:installationID/server-public-key"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/installation/:installationID/server-public-key HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/installation/:installationID/server-public-key")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/installation/:installationID/server-public-key"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/installation/:installationID/server-public-key")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/installation/:installationID/server-public-key")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/installation/:installationID/server-public-key');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/installation/:installationID/server-public-key',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/installation/:installationID/server-public-key';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/installation/:installationID/server-public-key',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/installation/:installationID/server-public-key")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/installation/:installationID/server-public-key',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/installation/:installationID/server-public-key',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/installation/:installationID/server-public-key');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/installation/:installationID/server-public-key',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/installation/:installationID/server-public-key';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/installation/:installationID/server-public-key"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/installation/:installationID/server-public-key" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/installation/:installationID/server-public-key",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/installation/:installationID/server-public-key', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/installation/:installationID/server-public-key');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/installation/:installationID/server-public-key');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/installation/:installationID/server-public-key' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/installation/:installationID/server-public-key' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/installation/:installationID/server-public-key", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/installation/:installationID/server-public-key"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/installation/:installationID/server-public-key"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/installation/:installationID/server-public-key")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/installation/:installationID/server-public-key') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/installation/:installationID/server-public-key";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".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}}/installation/:installationID/server-public-key \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/installation/:installationID/server-public-key \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/installation/:installationID/server-public-key
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/installation/:installationID/server-public-key")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_Session
{{baseUrl}}/session/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/session/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/session/:itemId" {:headers {:user-agent ""
                                                                        :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/session/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/session/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/session/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/session/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/session/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/session/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/session/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/session/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/session/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/session/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/session/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/session/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/session/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/session/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/session/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/session/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/session/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/session/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/session/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/session/:itemId"]
                                                       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}}/session/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/session/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/session/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/session/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/session/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/session/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/session/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/session/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/session/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/session/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/session/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/session/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/session/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/session/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/session/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/session/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/session/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_SessionServer
{{baseUrl}}/session-server
HEADERS

User-Agent
X-Bunq-Client-Authentication
BODY json

{
  "secret": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/session-server");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"secret\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/session-server" {:headers {:user-agent ""
                                                                     :x-bunq-client-authentication ""}
                                                           :content-type :json
                                                           :form-params {:secret ""}})
require "http/client"

url = "{{baseUrl}}/session-server"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"secret\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/session-server"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"secret\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/session-server");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"secret\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/session-server"

	payload := strings.NewReader("{\n  \"secret\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/session-server HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 18

{
  "secret": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/session-server")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"secret\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/session-server"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"secret\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"secret\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/session-server")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/session-server")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"secret\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  secret: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/session-server');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/session-server',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {secret: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/session-server';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"secret":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/session-server',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "secret": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"secret\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/session-server")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/session-server',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({secret: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/session-server',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {secret: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/session-server');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  secret: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/session-server',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {secret: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/session-server';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"secret":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"secret": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/session-server"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/session-server" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"secret\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/session-server",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'secret' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/session-server', [
  'body' => '{
  "secret": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/session-server');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'secret' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'secret' => ''
]));
$request->setRequestUrl('{{baseUrl}}/session-server');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/session-server' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "secret": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/session-server' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "secret": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"secret\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/session-server", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/session-server"

payload = { "secret": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/session-server"

payload <- "{\n  \"secret\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/session-server")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"secret\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/session-server') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"secret\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/session-server";

    let payload = json!({"secret": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/session-server \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "secret": ""
}'
echo '{
  "secret": ""
}' |  \
  http POST {{baseUrl}}/session-server \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "secret": ""\n}' \
  --output-document \
  - {{baseUrl}}/session-server
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["secret": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/session-server")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_ShareInviteMonetaryAccountInquiry_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
BODY json

{
  "access_type": "",
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "counter_user_alias": {},
  "draft_share_invite_bank_id": 0,
  "end_date": "",
  "id": 0,
  "monetary_account_id": 0,
  "relationship": "",
  "share_detail": {
    "draft_payment": {
      "make_draft_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "payment": {
      "make_draft_payments": false,
      "make_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "read_only": {
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    }
  },
  "share_type": "",
  "start_date": "",
  "status": "",
  "user_alias_created": {},
  "user_alias_revoked": {}
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"access_type\": \"\",\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"counter_user_alias\": {},\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relationship\": \"\",\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {}\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry" {:headers {:user-agent ""
                                                                                                                                              :x-bunq-client-authentication ""}
                                                                                                                                    :content-type :json
                                                                                                                                    :form-params {:access_type ""
                                                                                                                                                  :alias {:avatar {:anchor_uuid ""
                                                                                                                                                                   :image [{:attachment_public_uuid ""
                                                                                                                                                                            :content_type ""
                                                                                                                                                                            :height 0
                                                                                                                                                                            :width 0}]
                                                                                                                                                                   :style ""
                                                                                                                                                                   :uuid ""}
                                                                                                                                                          :bunq_me {:name ""
                                                                                                                                                                    :service ""
                                                                                                                                                                    :type ""
                                                                                                                                                                    :value ""}
                                                                                                                                                          :country ""
                                                                                                                                                          :display_name ""
                                                                                                                                                          :iban ""
                                                                                                                                                          :is_light false
                                                                                                                                                          :label_user {:avatar {}
                                                                                                                                                                       :country ""
                                                                                                                                                                       :display_name ""
                                                                                                                                                                       :public_nick_name ""
                                                                                                                                                                       :uuid ""}
                                                                                                                                                          :merchant_category_code ""
                                                                                                                                                          :swift_account_number ""
                                                                                                                                                          :swift_bic ""
                                                                                                                                                          :transferwise_account_number ""
                                                                                                                                                          :transferwise_bank_code ""}
                                                                                                                                                  :counter_user_alias {}
                                                                                                                                                  :draft_share_invite_bank_id 0
                                                                                                                                                  :end_date ""
                                                                                                                                                  :id 0
                                                                                                                                                  :monetary_account_id 0
                                                                                                                                                  :relationship ""
                                                                                                                                                  :share_detail {:draft_payment {:make_draft_payments false
                                                                                                                                                                                 :view_balance false
                                                                                                                                                                                 :view_new_events false
                                                                                                                                                                                 :view_old_events false}
                                                                                                                                                                 :payment {:make_draft_payments false
                                                                                                                                                                           :make_payments false
                                                                                                                                                                           :view_balance false
                                                                                                                                                                           :view_new_events false
                                                                                                                                                                           :view_old_events false}
                                                                                                                                                                 :read_only {:view_balance false
                                                                                                                                                                             :view_new_events false
                                                                                                                                                                             :view_old_events false}}
                                                                                                                                                  :share_type ""
                                                                                                                                                  :start_date ""
                                                                                                                                                  :status ""
                                                                                                                                                  :user_alias_created {}
                                                                                                                                                  :user_alias_revoked {}}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"access_type\": \"\",\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"counter_user_alias\": {},\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relationship\": \"\",\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {}\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"access_type\": \"\",\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"counter_user_alias\": {},\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relationship\": \"\",\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {}\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"access_type\": \"\",\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"counter_user_alias\": {},\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relationship\": \"\",\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {}\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry"

	payload := strings.NewReader("{\n  \"access_type\": \"\",\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"counter_user_alias\": {},\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relationship\": \"\",\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {}\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 1502

{
  "access_type": "",
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "counter_user_alias": {},
  "draft_share_invite_bank_id": 0,
  "end_date": "",
  "id": 0,
  "monetary_account_id": 0,
  "relationship": "",
  "share_detail": {
    "draft_payment": {
      "make_draft_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "payment": {
      "make_draft_payments": false,
      "make_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "read_only": {
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    }
  },
  "share_type": "",
  "start_date": "",
  "status": "",
  "user_alias_created": {},
  "user_alias_revoked": {}
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"access_type\": \"\",\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"counter_user_alias\": {},\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relationship\": \"\",\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {}\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"access_type\": \"\",\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"counter_user_alias\": {},\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relationship\": \"\",\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {}\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"access_type\": \"\",\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"counter_user_alias\": {},\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relationship\": \"\",\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {}\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"access_type\": \"\",\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"counter_user_alias\": {},\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relationship\": \"\",\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {}\n}")
  .asString();
const data = JSON.stringify({
  access_type: '',
  alias: {
    avatar: {
      anchor_uuid: '',
      image: [
        {
          attachment_public_uuid: '',
          content_type: '',
          height: 0,
          width: 0
        }
      ],
      style: '',
      uuid: ''
    },
    bunq_me: {
      name: '',
      service: '',
      type: '',
      value: ''
    },
    country: '',
    display_name: '',
    iban: '',
    is_light: false,
    label_user: {
      avatar: {},
      country: '',
      display_name: '',
      public_nick_name: '',
      uuid: ''
    },
    merchant_category_code: '',
    swift_account_number: '',
    swift_bic: '',
    transferwise_account_number: '',
    transferwise_bank_code: ''
  },
  counter_user_alias: {},
  draft_share_invite_bank_id: 0,
  end_date: '',
  id: 0,
  monetary_account_id: 0,
  relationship: '',
  share_detail: {
    draft_payment: {
      make_draft_payments: false,
      view_balance: false,
      view_new_events: false,
      view_old_events: false
    },
    payment: {
      make_draft_payments: false,
      make_payments: false,
      view_balance: false,
      view_new_events: false,
      view_old_events: false
    },
    read_only: {
      view_balance: false,
      view_new_events: false,
      view_old_events: false
    }
  },
  share_type: '',
  start_date: '',
  status: '',
  user_alias_created: {},
  user_alias_revoked: {}
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    access_type: '',
    alias: {
      avatar: {
        anchor_uuid: '',
        image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
        style: '',
        uuid: ''
      },
      bunq_me: {name: '', service: '', type: '', value: ''},
      country: '',
      display_name: '',
      iban: '',
      is_light: false,
      label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
      merchant_category_code: '',
      swift_account_number: '',
      swift_bic: '',
      transferwise_account_number: '',
      transferwise_bank_code: ''
    },
    counter_user_alias: {},
    draft_share_invite_bank_id: 0,
    end_date: '',
    id: 0,
    monetary_account_id: 0,
    relationship: '',
    share_detail: {
      draft_payment: {
        make_draft_payments: false,
        view_balance: false,
        view_new_events: false,
        view_old_events: false
      },
      payment: {
        make_draft_payments: false,
        make_payments: false,
        view_balance: false,
        view_new_events: false,
        view_old_events: false
      },
      read_only: {view_balance: false, view_new_events: false, view_old_events: false}
    },
    share_type: '',
    start_date: '',
    status: '',
    user_alias_created: {},
    user_alias_revoked: {}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"access_type":"","alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"counter_user_alias":{},"draft_share_invite_bank_id":0,"end_date":"","id":0,"monetary_account_id":0,"relationship":"","share_detail":{"draft_payment":{"make_draft_payments":false,"view_balance":false,"view_new_events":false,"view_old_events":false},"payment":{"make_draft_payments":false,"make_payments":false,"view_balance":false,"view_new_events":false,"view_old_events":false},"read_only":{"view_balance":false,"view_new_events":false,"view_old_events":false}},"share_type":"","start_date":"","status":"","user_alias_created":{},"user_alias_revoked":{}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "access_type": "",\n  "alias": {\n    "avatar": {\n      "anchor_uuid": "",\n      "image": [\n        {\n          "attachment_public_uuid": "",\n          "content_type": "",\n          "height": 0,\n          "width": 0\n        }\n      ],\n      "style": "",\n      "uuid": ""\n    },\n    "bunq_me": {\n      "name": "",\n      "service": "",\n      "type": "",\n      "value": ""\n    },\n    "country": "",\n    "display_name": "",\n    "iban": "",\n    "is_light": false,\n    "label_user": {\n      "avatar": {},\n      "country": "",\n      "display_name": "",\n      "public_nick_name": "",\n      "uuid": ""\n    },\n    "merchant_category_code": "",\n    "swift_account_number": "",\n    "swift_bic": "",\n    "transferwise_account_number": "",\n    "transferwise_bank_code": ""\n  },\n  "counter_user_alias": {},\n  "draft_share_invite_bank_id": 0,\n  "end_date": "",\n  "id": 0,\n  "monetary_account_id": 0,\n  "relationship": "",\n  "share_detail": {\n    "draft_payment": {\n      "make_draft_payments": false,\n      "view_balance": false,\n      "view_new_events": false,\n      "view_old_events": false\n    },\n    "payment": {\n      "make_draft_payments": false,\n      "make_payments": false,\n      "view_balance": false,\n      "view_new_events": false,\n      "view_old_events": false\n    },\n    "read_only": {\n      "view_balance": false,\n      "view_new_events": false,\n      "view_old_events": false\n    }\n  },\n  "share_type": "",\n  "start_date": "",\n  "status": "",\n  "user_alias_created": {},\n  "user_alias_revoked": {}\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"access_type\": \"\",\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"counter_user_alias\": {},\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relationship\": \"\",\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {}\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  access_type: '',
  alias: {
    avatar: {
      anchor_uuid: '',
      image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
      style: '',
      uuid: ''
    },
    bunq_me: {name: '', service: '', type: '', value: ''},
    country: '',
    display_name: '',
    iban: '',
    is_light: false,
    label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
    merchant_category_code: '',
    swift_account_number: '',
    swift_bic: '',
    transferwise_account_number: '',
    transferwise_bank_code: ''
  },
  counter_user_alias: {},
  draft_share_invite_bank_id: 0,
  end_date: '',
  id: 0,
  monetary_account_id: 0,
  relationship: '',
  share_detail: {
    draft_payment: {
      make_draft_payments: false,
      view_balance: false,
      view_new_events: false,
      view_old_events: false
    },
    payment: {
      make_draft_payments: false,
      make_payments: false,
      view_balance: false,
      view_new_events: false,
      view_old_events: false
    },
    read_only: {view_balance: false, view_new_events: false, view_old_events: false}
  },
  share_type: '',
  start_date: '',
  status: '',
  user_alias_created: {},
  user_alias_revoked: {}
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    access_type: '',
    alias: {
      avatar: {
        anchor_uuid: '',
        image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
        style: '',
        uuid: ''
      },
      bunq_me: {name: '', service: '', type: '', value: ''},
      country: '',
      display_name: '',
      iban: '',
      is_light: false,
      label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
      merchant_category_code: '',
      swift_account_number: '',
      swift_bic: '',
      transferwise_account_number: '',
      transferwise_bank_code: ''
    },
    counter_user_alias: {},
    draft_share_invite_bank_id: 0,
    end_date: '',
    id: 0,
    monetary_account_id: 0,
    relationship: '',
    share_detail: {
      draft_payment: {
        make_draft_payments: false,
        view_balance: false,
        view_new_events: false,
        view_old_events: false
      },
      payment: {
        make_draft_payments: false,
        make_payments: false,
        view_balance: false,
        view_new_events: false,
        view_old_events: false
      },
      read_only: {view_balance: false, view_new_events: false, view_old_events: false}
    },
    share_type: '',
    start_date: '',
    status: '',
    user_alias_created: {},
    user_alias_revoked: {}
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  access_type: '',
  alias: {
    avatar: {
      anchor_uuid: '',
      image: [
        {
          attachment_public_uuid: '',
          content_type: '',
          height: 0,
          width: 0
        }
      ],
      style: '',
      uuid: ''
    },
    bunq_me: {
      name: '',
      service: '',
      type: '',
      value: ''
    },
    country: '',
    display_name: '',
    iban: '',
    is_light: false,
    label_user: {
      avatar: {},
      country: '',
      display_name: '',
      public_nick_name: '',
      uuid: ''
    },
    merchant_category_code: '',
    swift_account_number: '',
    swift_bic: '',
    transferwise_account_number: '',
    transferwise_bank_code: ''
  },
  counter_user_alias: {},
  draft_share_invite_bank_id: 0,
  end_date: '',
  id: 0,
  monetary_account_id: 0,
  relationship: '',
  share_detail: {
    draft_payment: {
      make_draft_payments: false,
      view_balance: false,
      view_new_events: false,
      view_old_events: false
    },
    payment: {
      make_draft_payments: false,
      make_payments: false,
      view_balance: false,
      view_new_events: false,
      view_old_events: false
    },
    read_only: {
      view_balance: false,
      view_new_events: false,
      view_old_events: false
    }
  },
  share_type: '',
  start_date: '',
  status: '',
  user_alias_created: {},
  user_alias_revoked: {}
});

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}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    access_type: '',
    alias: {
      avatar: {
        anchor_uuid: '',
        image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
        style: '',
        uuid: ''
      },
      bunq_me: {name: '', service: '', type: '', value: ''},
      country: '',
      display_name: '',
      iban: '',
      is_light: false,
      label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
      merchant_category_code: '',
      swift_account_number: '',
      swift_bic: '',
      transferwise_account_number: '',
      transferwise_bank_code: ''
    },
    counter_user_alias: {},
    draft_share_invite_bank_id: 0,
    end_date: '',
    id: 0,
    monetary_account_id: 0,
    relationship: '',
    share_detail: {
      draft_payment: {
        make_draft_payments: false,
        view_balance: false,
        view_new_events: false,
        view_old_events: false
      },
      payment: {
        make_draft_payments: false,
        make_payments: false,
        view_balance: false,
        view_new_events: false,
        view_old_events: false
      },
      read_only: {view_balance: false, view_new_events: false, view_old_events: false}
    },
    share_type: '',
    start_date: '',
    status: '',
    user_alias_created: {},
    user_alias_revoked: {}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"access_type":"","alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"counter_user_alias":{},"draft_share_invite_bank_id":0,"end_date":"","id":0,"monetary_account_id":0,"relationship":"","share_detail":{"draft_payment":{"make_draft_payments":false,"view_balance":false,"view_new_events":false,"view_old_events":false},"payment":{"make_draft_payments":false,"make_payments":false,"view_balance":false,"view_new_events":false,"view_old_events":false},"read_only":{"view_balance":false,"view_new_events":false,"view_old_events":false}},"share_type":"","start_date":"","status":"","user_alias_created":{},"user_alias_revoked":{}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"access_type": @"",
                              @"alias": @{ @"avatar": @{ @"anchor_uuid": @"", @"image": @[ @{ @"attachment_public_uuid": @"", @"content_type": @"", @"height": @0, @"width": @0 } ], @"style": @"", @"uuid": @"" }, @"bunq_me": @{ @"name": @"", @"service": @"", @"type": @"", @"value": @"" }, @"country": @"", @"display_name": @"", @"iban": @"", @"is_light": @NO, @"label_user": @{ @"avatar": @{  }, @"country": @"", @"display_name": @"", @"public_nick_name": @"", @"uuid": @"" }, @"merchant_category_code": @"", @"swift_account_number": @"", @"swift_bic": @"", @"transferwise_account_number": @"", @"transferwise_bank_code": @"" },
                              @"counter_user_alias": @{  },
                              @"draft_share_invite_bank_id": @0,
                              @"end_date": @"",
                              @"id": @0,
                              @"monetary_account_id": @0,
                              @"relationship": @"",
                              @"share_detail": @{ @"draft_payment": @{ @"make_draft_payments": @NO, @"view_balance": @NO, @"view_new_events": @NO, @"view_old_events": @NO }, @"payment": @{ @"make_draft_payments": @NO, @"make_payments": @NO, @"view_balance": @NO, @"view_new_events": @NO, @"view_old_events": @NO }, @"read_only": @{ @"view_balance": @NO, @"view_new_events": @NO, @"view_old_events": @NO } },
                              @"share_type": @"",
                              @"start_date": @"",
                              @"status": @"",
                              @"user_alias_created": @{  },
                              @"user_alias_revoked": @{  } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"access_type\": \"\",\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"counter_user_alias\": {},\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relationship\": \"\",\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {}\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'access_type' => '',
    'alias' => [
        'avatar' => [
                'anchor_uuid' => '',
                'image' => [
                                [
                                                                'attachment_public_uuid' => '',
                                                                'content_type' => '',
                                                                'height' => 0,
                                                                'width' => 0
                                ]
                ],
                'style' => '',
                'uuid' => ''
        ],
        'bunq_me' => [
                'name' => '',
                'service' => '',
                'type' => '',
                'value' => ''
        ],
        'country' => '',
        'display_name' => '',
        'iban' => '',
        'is_light' => null,
        'label_user' => [
                'avatar' => [
                                
                ],
                'country' => '',
                'display_name' => '',
                'public_nick_name' => '',
                'uuid' => ''
        ],
        'merchant_category_code' => '',
        'swift_account_number' => '',
        'swift_bic' => '',
        'transferwise_account_number' => '',
        'transferwise_bank_code' => ''
    ],
    'counter_user_alias' => [
        
    ],
    'draft_share_invite_bank_id' => 0,
    'end_date' => '',
    'id' => 0,
    'monetary_account_id' => 0,
    'relationship' => '',
    'share_detail' => [
        'draft_payment' => [
                'make_draft_payments' => null,
                'view_balance' => null,
                'view_new_events' => null,
                'view_old_events' => null
        ],
        'payment' => [
                'make_draft_payments' => null,
                'make_payments' => null,
                'view_balance' => null,
                'view_new_events' => null,
                'view_old_events' => null
        ],
        'read_only' => [
                'view_balance' => null,
                'view_new_events' => null,
                'view_old_events' => null
        ]
    ],
    'share_type' => '',
    'start_date' => '',
    'status' => '',
    'user_alias_created' => [
        
    ],
    'user_alias_revoked' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry', [
  'body' => '{
  "access_type": "",
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "counter_user_alias": {},
  "draft_share_invite_bank_id": 0,
  "end_date": "",
  "id": 0,
  "monetary_account_id": 0,
  "relationship": "",
  "share_detail": {
    "draft_payment": {
      "make_draft_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "payment": {
      "make_draft_payments": false,
      "make_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "read_only": {
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    }
  },
  "share_type": "",
  "start_date": "",
  "status": "",
  "user_alias_created": {},
  "user_alias_revoked": {}
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'access_type' => '',
  'alias' => [
    'avatar' => [
        'anchor_uuid' => '',
        'image' => [
                [
                                'attachment_public_uuid' => '',
                                'content_type' => '',
                                'height' => 0,
                                'width' => 0
                ]
        ],
        'style' => '',
        'uuid' => ''
    ],
    'bunq_me' => [
        'name' => '',
        'service' => '',
        'type' => '',
        'value' => ''
    ],
    'country' => '',
    'display_name' => '',
    'iban' => '',
    'is_light' => null,
    'label_user' => [
        'avatar' => [
                
        ],
        'country' => '',
        'display_name' => '',
        'public_nick_name' => '',
        'uuid' => ''
    ],
    'merchant_category_code' => '',
    'swift_account_number' => '',
    'swift_bic' => '',
    'transferwise_account_number' => '',
    'transferwise_bank_code' => ''
  ],
  'counter_user_alias' => [
    
  ],
  'draft_share_invite_bank_id' => 0,
  'end_date' => '',
  'id' => 0,
  'monetary_account_id' => 0,
  'relationship' => '',
  'share_detail' => [
    'draft_payment' => [
        'make_draft_payments' => null,
        'view_balance' => null,
        'view_new_events' => null,
        'view_old_events' => null
    ],
    'payment' => [
        'make_draft_payments' => null,
        'make_payments' => null,
        'view_balance' => null,
        'view_new_events' => null,
        'view_old_events' => null
    ],
    'read_only' => [
        'view_balance' => null,
        'view_new_events' => null,
        'view_old_events' => null
    ]
  ],
  'share_type' => '',
  'start_date' => '',
  'status' => '',
  'user_alias_created' => [
    
  ],
  'user_alias_revoked' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'access_type' => '',
  'alias' => [
    'avatar' => [
        'anchor_uuid' => '',
        'image' => [
                [
                                'attachment_public_uuid' => '',
                                'content_type' => '',
                                'height' => 0,
                                'width' => 0
                ]
        ],
        'style' => '',
        'uuid' => ''
    ],
    'bunq_me' => [
        'name' => '',
        'service' => '',
        'type' => '',
        'value' => ''
    ],
    'country' => '',
    'display_name' => '',
    'iban' => '',
    'is_light' => null,
    'label_user' => [
        'avatar' => [
                
        ],
        'country' => '',
        'display_name' => '',
        'public_nick_name' => '',
        'uuid' => ''
    ],
    'merchant_category_code' => '',
    'swift_account_number' => '',
    'swift_bic' => '',
    'transferwise_account_number' => '',
    'transferwise_bank_code' => ''
  ],
  'counter_user_alias' => [
    
  ],
  'draft_share_invite_bank_id' => 0,
  'end_date' => '',
  'id' => 0,
  'monetary_account_id' => 0,
  'relationship' => '',
  'share_detail' => [
    'draft_payment' => [
        'make_draft_payments' => null,
        'view_balance' => null,
        'view_new_events' => null,
        'view_old_events' => null
    ],
    'payment' => [
        'make_draft_payments' => null,
        'make_payments' => null,
        'view_balance' => null,
        'view_new_events' => null,
        'view_old_events' => null
    ],
    'read_only' => [
        'view_balance' => null,
        'view_new_events' => null,
        'view_old_events' => null
    ]
  ],
  'share_type' => '',
  'start_date' => '',
  'status' => '',
  'user_alias_created' => [
    
  ],
  'user_alias_revoked' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "access_type": "",
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "counter_user_alias": {},
  "draft_share_invite_bank_id": 0,
  "end_date": "",
  "id": 0,
  "monetary_account_id": 0,
  "relationship": "",
  "share_detail": {
    "draft_payment": {
      "make_draft_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "payment": {
      "make_draft_payments": false,
      "make_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "read_only": {
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    }
  },
  "share_type": "",
  "start_date": "",
  "status": "",
  "user_alias_created": {},
  "user_alias_revoked": {}
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "access_type": "",
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "counter_user_alias": {},
  "draft_share_invite_bank_id": 0,
  "end_date": "",
  "id": 0,
  "monetary_account_id": 0,
  "relationship": "",
  "share_detail": {
    "draft_payment": {
      "make_draft_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "payment": {
      "make_draft_payments": false,
      "make_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "read_only": {
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    }
  },
  "share_type": "",
  "start_date": "",
  "status": "",
  "user_alias_created": {},
  "user_alias_revoked": {}
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"access_type\": \"\",\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"counter_user_alias\": {},\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relationship\": \"\",\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {}\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry"

payload = {
    "access_type": "",
    "alias": {
        "avatar": {
            "anchor_uuid": "",
            "image": [
                {
                    "attachment_public_uuid": "",
                    "content_type": "",
                    "height": 0,
                    "width": 0
                }
            ],
            "style": "",
            "uuid": ""
        },
        "bunq_me": {
            "name": "",
            "service": "",
            "type": "",
            "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": False,
        "label_user": {
            "avatar": {},
            "country": "",
            "display_name": "",
            "public_nick_name": "",
            "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
    },
    "counter_user_alias": {},
    "draft_share_invite_bank_id": 0,
    "end_date": "",
    "id": 0,
    "monetary_account_id": 0,
    "relationship": "",
    "share_detail": {
        "draft_payment": {
            "make_draft_payments": False,
            "view_balance": False,
            "view_new_events": False,
            "view_old_events": False
        },
        "payment": {
            "make_draft_payments": False,
            "make_payments": False,
            "view_balance": False,
            "view_new_events": False,
            "view_old_events": False
        },
        "read_only": {
            "view_balance": False,
            "view_new_events": False,
            "view_old_events": False
        }
    },
    "share_type": "",
    "start_date": "",
    "status": "",
    "user_alias_created": {},
    "user_alias_revoked": {}
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry"

payload <- "{\n  \"access_type\": \"\",\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"counter_user_alias\": {},\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relationship\": \"\",\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {}\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"access_type\": \"\",\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"counter_user_alias\": {},\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relationship\": \"\",\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {}\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"access_type\": \"\",\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"counter_user_alias\": {},\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relationship\": \"\",\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {}\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry";

    let payload = json!({
        "access_type": "",
        "alias": json!({
            "avatar": json!({
                "anchor_uuid": "",
                "image": (
                    json!({
                        "attachment_public_uuid": "",
                        "content_type": "",
                        "height": 0,
                        "width": 0
                    })
                ),
                "style": "",
                "uuid": ""
            }),
            "bunq_me": json!({
                "name": "",
                "service": "",
                "type": "",
                "value": ""
            }),
            "country": "",
            "display_name": "",
            "iban": "",
            "is_light": false,
            "label_user": json!({
                "avatar": json!({}),
                "country": "",
                "display_name": "",
                "public_nick_name": "",
                "uuid": ""
            }),
            "merchant_category_code": "",
            "swift_account_number": "",
            "swift_bic": "",
            "transferwise_account_number": "",
            "transferwise_bank_code": ""
        }),
        "counter_user_alias": json!({}),
        "draft_share_invite_bank_id": 0,
        "end_date": "",
        "id": 0,
        "monetary_account_id": 0,
        "relationship": "",
        "share_detail": json!({
            "draft_payment": json!({
                "make_draft_payments": false,
                "view_balance": false,
                "view_new_events": false,
                "view_old_events": false
            }),
            "payment": json!({
                "make_draft_payments": false,
                "make_payments": false,
                "view_balance": false,
                "view_new_events": false,
                "view_old_events": false
            }),
            "read_only": json!({
                "view_balance": false,
                "view_new_events": false,
                "view_old_events": false
            })
        }),
        "share_type": "",
        "start_date": "",
        "status": "",
        "user_alias_created": json!({}),
        "user_alias_revoked": json!({})
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "access_type": "",
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "counter_user_alias": {},
  "draft_share_invite_bank_id": 0,
  "end_date": "",
  "id": 0,
  "monetary_account_id": 0,
  "relationship": "",
  "share_detail": {
    "draft_payment": {
      "make_draft_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "payment": {
      "make_draft_payments": false,
      "make_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "read_only": {
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    }
  },
  "share_type": "",
  "start_date": "",
  "status": "",
  "user_alias_created": {},
  "user_alias_revoked": {}
}'
echo '{
  "access_type": "",
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "counter_user_alias": {},
  "draft_share_invite_bank_id": 0,
  "end_date": "",
  "id": 0,
  "monetary_account_id": 0,
  "relationship": "",
  "share_detail": {
    "draft_payment": {
      "make_draft_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "payment": {
      "make_draft_payments": false,
      "make_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "read_only": {
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    }
  },
  "share_type": "",
  "start_date": "",
  "status": "",
  "user_alias_created": {},
  "user_alias_revoked": {}
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "access_type": "",\n  "alias": {\n    "avatar": {\n      "anchor_uuid": "",\n      "image": [\n        {\n          "attachment_public_uuid": "",\n          "content_type": "",\n          "height": 0,\n          "width": 0\n        }\n      ],\n      "style": "",\n      "uuid": ""\n    },\n    "bunq_me": {\n      "name": "",\n      "service": "",\n      "type": "",\n      "value": ""\n    },\n    "country": "",\n    "display_name": "",\n    "iban": "",\n    "is_light": false,\n    "label_user": {\n      "avatar": {},\n      "country": "",\n      "display_name": "",\n      "public_nick_name": "",\n      "uuid": ""\n    },\n    "merchant_category_code": "",\n    "swift_account_number": "",\n    "swift_bic": "",\n    "transferwise_account_number": "",\n    "transferwise_bank_code": ""\n  },\n  "counter_user_alias": {},\n  "draft_share_invite_bank_id": 0,\n  "end_date": "",\n  "id": 0,\n  "monetary_account_id": 0,\n  "relationship": "",\n  "share_detail": {\n    "draft_payment": {\n      "make_draft_payments": false,\n      "view_balance": false,\n      "view_new_events": false,\n      "view_old_events": false\n    },\n    "payment": {\n      "make_draft_payments": false,\n      "make_payments": false,\n      "view_balance": false,\n      "view_new_events": false,\n      "view_old_events": false\n    },\n    "read_only": {\n      "view_balance": false,\n      "view_new_events": false,\n      "view_old_events": false\n    }\n  },\n  "share_type": "",\n  "start_date": "",\n  "status": "",\n  "user_alias_created": {},\n  "user_alias_revoked": {}\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "access_type": "",
  "alias": [
    "avatar": [
      "anchor_uuid": "",
      "image": [
        [
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        ]
      ],
      "style": "",
      "uuid": ""
    ],
    "bunq_me": [
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    ],
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": [
      "avatar": [],
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    ],
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  ],
  "counter_user_alias": [],
  "draft_share_invite_bank_id": 0,
  "end_date": "",
  "id": 0,
  "monetary_account_id": 0,
  "relationship": "",
  "share_detail": [
    "draft_payment": [
      "make_draft_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    ],
    "payment": [
      "make_draft_payments": false,
      "make_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    ],
    "read_only": [
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    ]
  ],
  "share_type": "",
  "start_date": "",
  "status": "",
  "user_alias_created": [],
  "user_alias_revoked": []
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_ShareInviteMonetaryAccountInquiry_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry" {:headers {:user-agent ""
                                                                                                                                             :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_ShareInviteMonetaryAccountInquiry_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId" {:headers {:user-agent ""
                                                                                                                                                     :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_ShareInviteMonetaryAccountInquiry_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
itemId
BODY json

{
  "access_type": "",
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "counter_user_alias": {},
  "draft_share_invite_bank_id": 0,
  "end_date": "",
  "id": 0,
  "monetary_account_id": 0,
  "relationship": "",
  "share_detail": {
    "draft_payment": {
      "make_draft_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "payment": {
      "make_draft_payments": false,
      "make_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "read_only": {
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    }
  },
  "share_type": "",
  "start_date": "",
  "status": "",
  "user_alias_created": {},
  "user_alias_revoked": {}
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"access_type\": \"\",\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"counter_user_alias\": {},\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relationship\": \"\",\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {}\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId" {:headers {:user-agent ""
                                                                                                                                                     :x-bunq-client-authentication ""}
                                                                                                                                           :content-type :json
                                                                                                                                           :form-params {:access_type ""
                                                                                                                                                         :alias {:avatar {:anchor_uuid ""
                                                                                                                                                                          :image [{:attachment_public_uuid ""
                                                                                                                                                                                   :content_type ""
                                                                                                                                                                                   :height 0
                                                                                                                                                                                   :width 0}]
                                                                                                                                                                          :style ""
                                                                                                                                                                          :uuid ""}
                                                                                                                                                                 :bunq_me {:name ""
                                                                                                                                                                           :service ""
                                                                                                                                                                           :type ""
                                                                                                                                                                           :value ""}
                                                                                                                                                                 :country ""
                                                                                                                                                                 :display_name ""
                                                                                                                                                                 :iban ""
                                                                                                                                                                 :is_light false
                                                                                                                                                                 :label_user {:avatar {}
                                                                                                                                                                              :country ""
                                                                                                                                                                              :display_name ""
                                                                                                                                                                              :public_nick_name ""
                                                                                                                                                                              :uuid ""}
                                                                                                                                                                 :merchant_category_code ""
                                                                                                                                                                 :swift_account_number ""
                                                                                                                                                                 :swift_bic ""
                                                                                                                                                                 :transferwise_account_number ""
                                                                                                                                                                 :transferwise_bank_code ""}
                                                                                                                                                         :counter_user_alias {}
                                                                                                                                                         :draft_share_invite_bank_id 0
                                                                                                                                                         :end_date ""
                                                                                                                                                         :id 0
                                                                                                                                                         :monetary_account_id 0
                                                                                                                                                         :relationship ""
                                                                                                                                                         :share_detail {:draft_payment {:make_draft_payments false
                                                                                                                                                                                        :view_balance false
                                                                                                                                                                                        :view_new_events false
                                                                                                                                                                                        :view_old_events false}
                                                                                                                                                                        :payment {:make_draft_payments false
                                                                                                                                                                                  :make_payments false
                                                                                                                                                                                  :view_balance false
                                                                                                                                                                                  :view_new_events false
                                                                                                                                                                                  :view_old_events false}
                                                                                                                                                                        :read_only {:view_balance false
                                                                                                                                                                                    :view_new_events false
                                                                                                                                                                                    :view_old_events false}}
                                                                                                                                                         :share_type ""
                                                                                                                                                         :start_date ""
                                                                                                                                                         :status ""
                                                                                                                                                         :user_alias_created {}
                                                                                                                                                         :user_alias_revoked {}}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"access_type\": \"\",\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"counter_user_alias\": {},\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relationship\": \"\",\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {}\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"access_type\": \"\",\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"counter_user_alias\": {},\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relationship\": \"\",\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {}\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"access_type\": \"\",\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"counter_user_alias\": {},\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relationship\": \"\",\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {}\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId"

	payload := strings.NewReader("{\n  \"access_type\": \"\",\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"counter_user_alias\": {},\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relationship\": \"\",\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {}\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 1502

{
  "access_type": "",
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "counter_user_alias": {},
  "draft_share_invite_bank_id": 0,
  "end_date": "",
  "id": 0,
  "monetary_account_id": 0,
  "relationship": "",
  "share_detail": {
    "draft_payment": {
      "make_draft_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "payment": {
      "make_draft_payments": false,
      "make_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "read_only": {
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    }
  },
  "share_type": "",
  "start_date": "",
  "status": "",
  "user_alias_created": {},
  "user_alias_revoked": {}
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"access_type\": \"\",\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"counter_user_alias\": {},\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relationship\": \"\",\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {}\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"access_type\": \"\",\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"counter_user_alias\": {},\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relationship\": \"\",\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {}\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"access_type\": \"\",\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"counter_user_alias\": {},\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relationship\": \"\",\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {}\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"access_type\": \"\",\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"counter_user_alias\": {},\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relationship\": \"\",\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {}\n}")
  .asString();
const data = JSON.stringify({
  access_type: '',
  alias: {
    avatar: {
      anchor_uuid: '',
      image: [
        {
          attachment_public_uuid: '',
          content_type: '',
          height: 0,
          width: 0
        }
      ],
      style: '',
      uuid: ''
    },
    bunq_me: {
      name: '',
      service: '',
      type: '',
      value: ''
    },
    country: '',
    display_name: '',
    iban: '',
    is_light: false,
    label_user: {
      avatar: {},
      country: '',
      display_name: '',
      public_nick_name: '',
      uuid: ''
    },
    merchant_category_code: '',
    swift_account_number: '',
    swift_bic: '',
    transferwise_account_number: '',
    transferwise_bank_code: ''
  },
  counter_user_alias: {},
  draft_share_invite_bank_id: 0,
  end_date: '',
  id: 0,
  monetary_account_id: 0,
  relationship: '',
  share_detail: {
    draft_payment: {
      make_draft_payments: false,
      view_balance: false,
      view_new_events: false,
      view_old_events: false
    },
    payment: {
      make_draft_payments: false,
      make_payments: false,
      view_balance: false,
      view_new_events: false,
      view_old_events: false
    },
    read_only: {
      view_balance: false,
      view_new_events: false,
      view_old_events: false
    }
  },
  share_type: '',
  start_date: '',
  status: '',
  user_alias_created: {},
  user_alias_revoked: {}
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    access_type: '',
    alias: {
      avatar: {
        anchor_uuid: '',
        image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
        style: '',
        uuid: ''
      },
      bunq_me: {name: '', service: '', type: '', value: ''},
      country: '',
      display_name: '',
      iban: '',
      is_light: false,
      label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
      merchant_category_code: '',
      swift_account_number: '',
      swift_bic: '',
      transferwise_account_number: '',
      transferwise_bank_code: ''
    },
    counter_user_alias: {},
    draft_share_invite_bank_id: 0,
    end_date: '',
    id: 0,
    monetary_account_id: 0,
    relationship: '',
    share_detail: {
      draft_payment: {
        make_draft_payments: false,
        view_balance: false,
        view_new_events: false,
        view_old_events: false
      },
      payment: {
        make_draft_payments: false,
        make_payments: false,
        view_balance: false,
        view_new_events: false,
        view_old_events: false
      },
      read_only: {view_balance: false, view_new_events: false, view_old_events: false}
    },
    share_type: '',
    start_date: '',
    status: '',
    user_alias_created: {},
    user_alias_revoked: {}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"access_type":"","alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"counter_user_alias":{},"draft_share_invite_bank_id":0,"end_date":"","id":0,"monetary_account_id":0,"relationship":"","share_detail":{"draft_payment":{"make_draft_payments":false,"view_balance":false,"view_new_events":false,"view_old_events":false},"payment":{"make_draft_payments":false,"make_payments":false,"view_balance":false,"view_new_events":false,"view_old_events":false},"read_only":{"view_balance":false,"view_new_events":false,"view_old_events":false}},"share_type":"","start_date":"","status":"","user_alias_created":{},"user_alias_revoked":{}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "access_type": "",\n  "alias": {\n    "avatar": {\n      "anchor_uuid": "",\n      "image": [\n        {\n          "attachment_public_uuid": "",\n          "content_type": "",\n          "height": 0,\n          "width": 0\n        }\n      ],\n      "style": "",\n      "uuid": ""\n    },\n    "bunq_me": {\n      "name": "",\n      "service": "",\n      "type": "",\n      "value": ""\n    },\n    "country": "",\n    "display_name": "",\n    "iban": "",\n    "is_light": false,\n    "label_user": {\n      "avatar": {},\n      "country": "",\n      "display_name": "",\n      "public_nick_name": "",\n      "uuid": ""\n    },\n    "merchant_category_code": "",\n    "swift_account_number": "",\n    "swift_bic": "",\n    "transferwise_account_number": "",\n    "transferwise_bank_code": ""\n  },\n  "counter_user_alias": {},\n  "draft_share_invite_bank_id": 0,\n  "end_date": "",\n  "id": 0,\n  "monetary_account_id": 0,\n  "relationship": "",\n  "share_detail": {\n    "draft_payment": {\n      "make_draft_payments": false,\n      "view_balance": false,\n      "view_new_events": false,\n      "view_old_events": false\n    },\n    "payment": {\n      "make_draft_payments": false,\n      "make_payments": false,\n      "view_balance": false,\n      "view_new_events": false,\n      "view_old_events": false\n    },\n    "read_only": {\n      "view_balance": false,\n      "view_new_events": false,\n      "view_old_events": false\n    }\n  },\n  "share_type": "",\n  "start_date": "",\n  "status": "",\n  "user_alias_created": {},\n  "user_alias_revoked": {}\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"access_type\": \"\",\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"counter_user_alias\": {},\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relationship\": \"\",\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {}\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  access_type: '',
  alias: {
    avatar: {
      anchor_uuid: '',
      image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
      style: '',
      uuid: ''
    },
    bunq_me: {name: '', service: '', type: '', value: ''},
    country: '',
    display_name: '',
    iban: '',
    is_light: false,
    label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
    merchant_category_code: '',
    swift_account_number: '',
    swift_bic: '',
    transferwise_account_number: '',
    transferwise_bank_code: ''
  },
  counter_user_alias: {},
  draft_share_invite_bank_id: 0,
  end_date: '',
  id: 0,
  monetary_account_id: 0,
  relationship: '',
  share_detail: {
    draft_payment: {
      make_draft_payments: false,
      view_balance: false,
      view_new_events: false,
      view_old_events: false
    },
    payment: {
      make_draft_payments: false,
      make_payments: false,
      view_balance: false,
      view_new_events: false,
      view_old_events: false
    },
    read_only: {view_balance: false, view_new_events: false, view_old_events: false}
  },
  share_type: '',
  start_date: '',
  status: '',
  user_alias_created: {},
  user_alias_revoked: {}
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    access_type: '',
    alias: {
      avatar: {
        anchor_uuid: '',
        image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
        style: '',
        uuid: ''
      },
      bunq_me: {name: '', service: '', type: '', value: ''},
      country: '',
      display_name: '',
      iban: '',
      is_light: false,
      label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
      merchant_category_code: '',
      swift_account_number: '',
      swift_bic: '',
      transferwise_account_number: '',
      transferwise_bank_code: ''
    },
    counter_user_alias: {},
    draft_share_invite_bank_id: 0,
    end_date: '',
    id: 0,
    monetary_account_id: 0,
    relationship: '',
    share_detail: {
      draft_payment: {
        make_draft_payments: false,
        view_balance: false,
        view_new_events: false,
        view_old_events: false
      },
      payment: {
        make_draft_payments: false,
        make_payments: false,
        view_balance: false,
        view_new_events: false,
        view_old_events: false
      },
      read_only: {view_balance: false, view_new_events: false, view_old_events: false}
    },
    share_type: '',
    start_date: '',
    status: '',
    user_alias_created: {},
    user_alias_revoked: {}
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  access_type: '',
  alias: {
    avatar: {
      anchor_uuid: '',
      image: [
        {
          attachment_public_uuid: '',
          content_type: '',
          height: 0,
          width: 0
        }
      ],
      style: '',
      uuid: ''
    },
    bunq_me: {
      name: '',
      service: '',
      type: '',
      value: ''
    },
    country: '',
    display_name: '',
    iban: '',
    is_light: false,
    label_user: {
      avatar: {},
      country: '',
      display_name: '',
      public_nick_name: '',
      uuid: ''
    },
    merchant_category_code: '',
    swift_account_number: '',
    swift_bic: '',
    transferwise_account_number: '',
    transferwise_bank_code: ''
  },
  counter_user_alias: {},
  draft_share_invite_bank_id: 0,
  end_date: '',
  id: 0,
  monetary_account_id: 0,
  relationship: '',
  share_detail: {
    draft_payment: {
      make_draft_payments: false,
      view_balance: false,
      view_new_events: false,
      view_old_events: false
    },
    payment: {
      make_draft_payments: false,
      make_payments: false,
      view_balance: false,
      view_new_events: false,
      view_old_events: false
    },
    read_only: {
      view_balance: false,
      view_new_events: false,
      view_old_events: false
    }
  },
  share_type: '',
  start_date: '',
  status: '',
  user_alias_created: {},
  user_alias_revoked: {}
});

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}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    access_type: '',
    alias: {
      avatar: {
        anchor_uuid: '',
        image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
        style: '',
        uuid: ''
      },
      bunq_me: {name: '', service: '', type: '', value: ''},
      country: '',
      display_name: '',
      iban: '',
      is_light: false,
      label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
      merchant_category_code: '',
      swift_account_number: '',
      swift_bic: '',
      transferwise_account_number: '',
      transferwise_bank_code: ''
    },
    counter_user_alias: {},
    draft_share_invite_bank_id: 0,
    end_date: '',
    id: 0,
    monetary_account_id: 0,
    relationship: '',
    share_detail: {
      draft_payment: {
        make_draft_payments: false,
        view_balance: false,
        view_new_events: false,
        view_old_events: false
      },
      payment: {
        make_draft_payments: false,
        make_payments: false,
        view_balance: false,
        view_new_events: false,
        view_old_events: false
      },
      read_only: {view_balance: false, view_new_events: false, view_old_events: false}
    },
    share_type: '',
    start_date: '',
    status: '',
    user_alias_created: {},
    user_alias_revoked: {}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"access_type":"","alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"counter_user_alias":{},"draft_share_invite_bank_id":0,"end_date":"","id":0,"monetary_account_id":0,"relationship":"","share_detail":{"draft_payment":{"make_draft_payments":false,"view_balance":false,"view_new_events":false,"view_old_events":false},"payment":{"make_draft_payments":false,"make_payments":false,"view_balance":false,"view_new_events":false,"view_old_events":false},"read_only":{"view_balance":false,"view_new_events":false,"view_old_events":false}},"share_type":"","start_date":"","status":"","user_alias_created":{},"user_alias_revoked":{}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"access_type": @"",
                              @"alias": @{ @"avatar": @{ @"anchor_uuid": @"", @"image": @[ @{ @"attachment_public_uuid": @"", @"content_type": @"", @"height": @0, @"width": @0 } ], @"style": @"", @"uuid": @"" }, @"bunq_me": @{ @"name": @"", @"service": @"", @"type": @"", @"value": @"" }, @"country": @"", @"display_name": @"", @"iban": @"", @"is_light": @NO, @"label_user": @{ @"avatar": @{  }, @"country": @"", @"display_name": @"", @"public_nick_name": @"", @"uuid": @"" }, @"merchant_category_code": @"", @"swift_account_number": @"", @"swift_bic": @"", @"transferwise_account_number": @"", @"transferwise_bank_code": @"" },
                              @"counter_user_alias": @{  },
                              @"draft_share_invite_bank_id": @0,
                              @"end_date": @"",
                              @"id": @0,
                              @"monetary_account_id": @0,
                              @"relationship": @"",
                              @"share_detail": @{ @"draft_payment": @{ @"make_draft_payments": @NO, @"view_balance": @NO, @"view_new_events": @NO, @"view_old_events": @NO }, @"payment": @{ @"make_draft_payments": @NO, @"make_payments": @NO, @"view_balance": @NO, @"view_new_events": @NO, @"view_old_events": @NO }, @"read_only": @{ @"view_balance": @NO, @"view_new_events": @NO, @"view_old_events": @NO } },
                              @"share_type": @"",
                              @"start_date": @"",
                              @"status": @"",
                              @"user_alias_created": @{  },
                              @"user_alias_revoked": @{  } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"access_type\": \"\",\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"counter_user_alias\": {},\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relationship\": \"\",\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {}\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'access_type' => '',
    'alias' => [
        'avatar' => [
                'anchor_uuid' => '',
                'image' => [
                                [
                                                                'attachment_public_uuid' => '',
                                                                'content_type' => '',
                                                                'height' => 0,
                                                                'width' => 0
                                ]
                ],
                'style' => '',
                'uuid' => ''
        ],
        'bunq_me' => [
                'name' => '',
                'service' => '',
                'type' => '',
                'value' => ''
        ],
        'country' => '',
        'display_name' => '',
        'iban' => '',
        'is_light' => null,
        'label_user' => [
                'avatar' => [
                                
                ],
                'country' => '',
                'display_name' => '',
                'public_nick_name' => '',
                'uuid' => ''
        ],
        'merchant_category_code' => '',
        'swift_account_number' => '',
        'swift_bic' => '',
        'transferwise_account_number' => '',
        'transferwise_bank_code' => ''
    ],
    'counter_user_alias' => [
        
    ],
    'draft_share_invite_bank_id' => 0,
    'end_date' => '',
    'id' => 0,
    'monetary_account_id' => 0,
    'relationship' => '',
    'share_detail' => [
        'draft_payment' => [
                'make_draft_payments' => null,
                'view_balance' => null,
                'view_new_events' => null,
                'view_old_events' => null
        ],
        'payment' => [
                'make_draft_payments' => null,
                'make_payments' => null,
                'view_balance' => null,
                'view_new_events' => null,
                'view_old_events' => null
        ],
        'read_only' => [
                'view_balance' => null,
                'view_new_events' => null,
                'view_old_events' => null
        ]
    ],
    'share_type' => '',
    'start_date' => '',
    'status' => '',
    'user_alias_created' => [
        
    ],
    'user_alias_revoked' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId', [
  'body' => '{
  "access_type": "",
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "counter_user_alias": {},
  "draft_share_invite_bank_id": 0,
  "end_date": "",
  "id": 0,
  "monetary_account_id": 0,
  "relationship": "",
  "share_detail": {
    "draft_payment": {
      "make_draft_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "payment": {
      "make_draft_payments": false,
      "make_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "read_only": {
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    }
  },
  "share_type": "",
  "start_date": "",
  "status": "",
  "user_alias_created": {},
  "user_alias_revoked": {}
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'access_type' => '',
  'alias' => [
    'avatar' => [
        'anchor_uuid' => '',
        'image' => [
                [
                                'attachment_public_uuid' => '',
                                'content_type' => '',
                                'height' => 0,
                                'width' => 0
                ]
        ],
        'style' => '',
        'uuid' => ''
    ],
    'bunq_me' => [
        'name' => '',
        'service' => '',
        'type' => '',
        'value' => ''
    ],
    'country' => '',
    'display_name' => '',
    'iban' => '',
    'is_light' => null,
    'label_user' => [
        'avatar' => [
                
        ],
        'country' => '',
        'display_name' => '',
        'public_nick_name' => '',
        'uuid' => ''
    ],
    'merchant_category_code' => '',
    'swift_account_number' => '',
    'swift_bic' => '',
    'transferwise_account_number' => '',
    'transferwise_bank_code' => ''
  ],
  'counter_user_alias' => [
    
  ],
  'draft_share_invite_bank_id' => 0,
  'end_date' => '',
  'id' => 0,
  'monetary_account_id' => 0,
  'relationship' => '',
  'share_detail' => [
    'draft_payment' => [
        'make_draft_payments' => null,
        'view_balance' => null,
        'view_new_events' => null,
        'view_old_events' => null
    ],
    'payment' => [
        'make_draft_payments' => null,
        'make_payments' => null,
        'view_balance' => null,
        'view_new_events' => null,
        'view_old_events' => null
    ],
    'read_only' => [
        'view_balance' => null,
        'view_new_events' => null,
        'view_old_events' => null
    ]
  ],
  'share_type' => '',
  'start_date' => '',
  'status' => '',
  'user_alias_created' => [
    
  ],
  'user_alias_revoked' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'access_type' => '',
  'alias' => [
    'avatar' => [
        'anchor_uuid' => '',
        'image' => [
                [
                                'attachment_public_uuid' => '',
                                'content_type' => '',
                                'height' => 0,
                                'width' => 0
                ]
        ],
        'style' => '',
        'uuid' => ''
    ],
    'bunq_me' => [
        'name' => '',
        'service' => '',
        'type' => '',
        'value' => ''
    ],
    'country' => '',
    'display_name' => '',
    'iban' => '',
    'is_light' => null,
    'label_user' => [
        'avatar' => [
                
        ],
        'country' => '',
        'display_name' => '',
        'public_nick_name' => '',
        'uuid' => ''
    ],
    'merchant_category_code' => '',
    'swift_account_number' => '',
    'swift_bic' => '',
    'transferwise_account_number' => '',
    'transferwise_bank_code' => ''
  ],
  'counter_user_alias' => [
    
  ],
  'draft_share_invite_bank_id' => 0,
  'end_date' => '',
  'id' => 0,
  'monetary_account_id' => 0,
  'relationship' => '',
  'share_detail' => [
    'draft_payment' => [
        'make_draft_payments' => null,
        'view_balance' => null,
        'view_new_events' => null,
        'view_old_events' => null
    ],
    'payment' => [
        'make_draft_payments' => null,
        'make_payments' => null,
        'view_balance' => null,
        'view_new_events' => null,
        'view_old_events' => null
    ],
    'read_only' => [
        'view_balance' => null,
        'view_new_events' => null,
        'view_old_events' => null
    ]
  ],
  'share_type' => '',
  'start_date' => '',
  'status' => '',
  'user_alias_created' => [
    
  ],
  'user_alias_revoked' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "access_type": "",
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "counter_user_alias": {},
  "draft_share_invite_bank_id": 0,
  "end_date": "",
  "id": 0,
  "monetary_account_id": 0,
  "relationship": "",
  "share_detail": {
    "draft_payment": {
      "make_draft_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "payment": {
      "make_draft_payments": false,
      "make_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "read_only": {
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    }
  },
  "share_type": "",
  "start_date": "",
  "status": "",
  "user_alias_created": {},
  "user_alias_revoked": {}
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "access_type": "",
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "counter_user_alias": {},
  "draft_share_invite_bank_id": 0,
  "end_date": "",
  "id": 0,
  "monetary_account_id": 0,
  "relationship": "",
  "share_detail": {
    "draft_payment": {
      "make_draft_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "payment": {
      "make_draft_payments": false,
      "make_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "read_only": {
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    }
  },
  "share_type": "",
  "start_date": "",
  "status": "",
  "user_alias_created": {},
  "user_alias_revoked": {}
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"access_type\": \"\",\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"counter_user_alias\": {},\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relationship\": \"\",\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {}\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId"

payload = {
    "access_type": "",
    "alias": {
        "avatar": {
            "anchor_uuid": "",
            "image": [
                {
                    "attachment_public_uuid": "",
                    "content_type": "",
                    "height": 0,
                    "width": 0
                }
            ],
            "style": "",
            "uuid": ""
        },
        "bunq_me": {
            "name": "",
            "service": "",
            "type": "",
            "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": False,
        "label_user": {
            "avatar": {},
            "country": "",
            "display_name": "",
            "public_nick_name": "",
            "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
    },
    "counter_user_alias": {},
    "draft_share_invite_bank_id": 0,
    "end_date": "",
    "id": 0,
    "monetary_account_id": 0,
    "relationship": "",
    "share_detail": {
        "draft_payment": {
            "make_draft_payments": False,
            "view_balance": False,
            "view_new_events": False,
            "view_old_events": False
        },
        "payment": {
            "make_draft_payments": False,
            "make_payments": False,
            "view_balance": False,
            "view_new_events": False,
            "view_old_events": False
        },
        "read_only": {
            "view_balance": False,
            "view_new_events": False,
            "view_old_events": False
        }
    },
    "share_type": "",
    "start_date": "",
    "status": "",
    "user_alias_created": {},
    "user_alias_revoked": {}
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId"

payload <- "{\n  \"access_type\": \"\",\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"counter_user_alias\": {},\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relationship\": \"\",\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {}\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"access_type\": \"\",\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"counter_user_alias\": {},\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relationship\": \"\",\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {}\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"access_type\": \"\",\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"counter_user_alias\": {},\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relationship\": \"\",\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"user_alias_created\": {},\n  \"user_alias_revoked\": {}\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId";

    let payload = json!({
        "access_type": "",
        "alias": json!({
            "avatar": json!({
                "anchor_uuid": "",
                "image": (
                    json!({
                        "attachment_public_uuid": "",
                        "content_type": "",
                        "height": 0,
                        "width": 0
                    })
                ),
                "style": "",
                "uuid": ""
            }),
            "bunq_me": json!({
                "name": "",
                "service": "",
                "type": "",
                "value": ""
            }),
            "country": "",
            "display_name": "",
            "iban": "",
            "is_light": false,
            "label_user": json!({
                "avatar": json!({}),
                "country": "",
                "display_name": "",
                "public_nick_name": "",
                "uuid": ""
            }),
            "merchant_category_code": "",
            "swift_account_number": "",
            "swift_bic": "",
            "transferwise_account_number": "",
            "transferwise_bank_code": ""
        }),
        "counter_user_alias": json!({}),
        "draft_share_invite_bank_id": 0,
        "end_date": "",
        "id": 0,
        "monetary_account_id": 0,
        "relationship": "",
        "share_detail": json!({
            "draft_payment": json!({
                "make_draft_payments": false,
                "view_balance": false,
                "view_new_events": false,
                "view_old_events": false
            }),
            "payment": json!({
                "make_draft_payments": false,
                "make_payments": false,
                "view_balance": false,
                "view_new_events": false,
                "view_old_events": false
            }),
            "read_only": json!({
                "view_balance": false,
                "view_new_events": false,
                "view_old_events": false
            })
        }),
        "share_type": "",
        "start_date": "",
        "status": "",
        "user_alias_created": json!({}),
        "user_alias_revoked": json!({})
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "access_type": "",
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "counter_user_alias": {},
  "draft_share_invite_bank_id": 0,
  "end_date": "",
  "id": 0,
  "monetary_account_id": 0,
  "relationship": "",
  "share_detail": {
    "draft_payment": {
      "make_draft_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "payment": {
      "make_draft_payments": false,
      "make_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "read_only": {
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    }
  },
  "share_type": "",
  "start_date": "",
  "status": "",
  "user_alias_created": {},
  "user_alias_revoked": {}
}'
echo '{
  "access_type": "",
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "counter_user_alias": {},
  "draft_share_invite_bank_id": 0,
  "end_date": "",
  "id": 0,
  "monetary_account_id": 0,
  "relationship": "",
  "share_detail": {
    "draft_payment": {
      "make_draft_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "payment": {
      "make_draft_payments": false,
      "make_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "read_only": {
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    }
  },
  "share_type": "",
  "start_date": "",
  "status": "",
  "user_alias_created": {},
  "user_alias_revoked": {}
}' |  \
  http PUT {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "access_type": "",\n  "alias": {\n    "avatar": {\n      "anchor_uuid": "",\n      "image": [\n        {\n          "attachment_public_uuid": "",\n          "content_type": "",\n          "height": 0,\n          "width": 0\n        }\n      ],\n      "style": "",\n      "uuid": ""\n    },\n    "bunq_me": {\n      "name": "",\n      "service": "",\n      "type": "",\n      "value": ""\n    },\n    "country": "",\n    "display_name": "",\n    "iban": "",\n    "is_light": false,\n    "label_user": {\n      "avatar": {},\n      "country": "",\n      "display_name": "",\n      "public_nick_name": "",\n      "uuid": ""\n    },\n    "merchant_category_code": "",\n    "swift_account_number": "",\n    "swift_bic": "",\n    "transferwise_account_number": "",\n    "transferwise_bank_code": ""\n  },\n  "counter_user_alias": {},\n  "draft_share_invite_bank_id": 0,\n  "end_date": "",\n  "id": 0,\n  "monetary_account_id": 0,\n  "relationship": "",\n  "share_detail": {\n    "draft_payment": {\n      "make_draft_payments": false,\n      "view_balance": false,\n      "view_new_events": false,\n      "view_old_events": false\n    },\n    "payment": {\n      "make_draft_payments": false,\n      "make_payments": false,\n      "view_balance": false,\n      "view_new_events": false,\n      "view_old_events": false\n    },\n    "read_only": {\n      "view_balance": false,\n      "view_new_events": false,\n      "view_old_events": false\n    }\n  },\n  "share_type": "",\n  "start_date": "",\n  "status": "",\n  "user_alias_created": {},\n  "user_alias_revoked": {}\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "access_type": "",
  "alias": [
    "avatar": [
      "anchor_uuid": "",
      "image": [
        [
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        ]
      ],
      "style": "",
      "uuid": ""
    ],
    "bunq_me": [
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    ],
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": [
      "avatar": [],
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    ],
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  ],
  "counter_user_alias": [],
  "draft_share_invite_bank_id": 0,
  "end_date": "",
  "id": 0,
  "monetary_account_id": 0,
  "relationship": "",
  "share_detail": [
    "draft_payment": [
      "make_draft_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    ],
    "payment": [
      "make_draft_payments": false,
      "make_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    ],
    "read_only": [
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    ]
  ],
  "share_type": "",
  "start_date": "",
  "status": "",
  "user_alias_created": [],
  "user_alias_revoked": []
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/share-invite-monetary-account-inquiry/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_ShareInviteMonetaryAccountResponse_for_User
{{baseUrl}}/user/:userID/share-invite-monetary-account-response
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/share-invite-monetary-account-response");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/share-invite-monetary-account-response" {:headers {:user-agent ""
                                                                                                         :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/share-invite-monetary-account-response"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/share-invite-monetary-account-response"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/share-invite-monetary-account-response");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/share-invite-monetary-account-response"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/share-invite-monetary-account-response HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/share-invite-monetary-account-response")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/share-invite-monetary-account-response"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/share-invite-monetary-account-response")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/share-invite-monetary-account-response")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/share-invite-monetary-account-response');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/share-invite-monetary-account-response',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/share-invite-monetary-account-response';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/share-invite-monetary-account-response',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/share-invite-monetary-account-response")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/share-invite-monetary-account-response',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/share-invite-monetary-account-response',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/share-invite-monetary-account-response');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/share-invite-monetary-account-response',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/share-invite-monetary-account-response';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/share-invite-monetary-account-response"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/share-invite-monetary-account-response" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/share-invite-monetary-account-response",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/share-invite-monetary-account-response', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/share-invite-monetary-account-response');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/share-invite-monetary-account-response');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/share-invite-monetary-account-response' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/share-invite-monetary-account-response' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/share-invite-monetary-account-response", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/share-invite-monetary-account-response"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/share-invite-monetary-account-response"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/share-invite-monetary-account-response")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/share-invite-monetary-account-response') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/share-invite-monetary-account-response";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/share-invite-monetary-account-response \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/share-invite-monetary-account-response \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/share-invite-monetary-account-response
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/share-invite-monetary-account-response")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_ShareInviteMonetaryAccountResponse_for_User
{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId" {:headers {:user-agent ""
                                                                                                                 :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/share-invite-monetary-account-response/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/share-invite-monetary-account-response/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/share-invite-monetary-account-response/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/share-invite-monetary-account-response/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_ShareInviteMonetaryAccountResponse_for_User
{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
BODY json

{
  "access_type": "",
  "card_id": 0,
  "counter_alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "created": "",
  "description": "",
  "draft_share_invite_bank_id": 0,
  "end_date": "",
  "id": 0,
  "monetary_account_id": 0,
  "relation_user": {
    "counter_label_user": {},
    "counter_user_id": "",
    "counter_user_status": "",
    "label_user": {},
    "relationship": "",
    "status": "",
    "user_id": "",
    "user_status": ""
  },
  "share_detail": {
    "draft_payment": {
      "make_draft_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "payment": {
      "make_draft_payments": false,
      "make_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "read_only": {
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    }
  },
  "share_type": "",
  "start_date": "",
  "status": "",
  "updated": "",
  "user_alias_cancelled": {}
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"access_type\": \"\",\n  \"card_id\": 0,\n  \"counter_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relation_user\": {\n    \"counter_label_user\": {},\n    \"counter_user_id\": \"\",\n    \"counter_user_status\": \"\",\n    \"label_user\": {},\n    \"relationship\": \"\",\n    \"status\": \"\",\n    \"user_id\": \"\",\n    \"user_status\": \"\"\n  },\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"updated\": \"\",\n  \"user_alias_cancelled\": {}\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId" {:headers {:user-agent ""
                                                                                                                 :x-bunq-client-authentication ""}
                                                                                                       :content-type :json
                                                                                                       :form-params {:access_type ""
                                                                                                                     :card_id 0
                                                                                                                     :counter_alias {:avatar {:anchor_uuid ""
                                                                                                                                              :image [{:attachment_public_uuid ""
                                                                                                                                                       :content_type ""
                                                                                                                                                       :height 0
                                                                                                                                                       :width 0}]
                                                                                                                                              :style ""
                                                                                                                                              :uuid ""}
                                                                                                                                     :bunq_me {:name ""
                                                                                                                                               :service ""
                                                                                                                                               :type ""
                                                                                                                                               :value ""}
                                                                                                                                     :country ""
                                                                                                                                     :display_name ""
                                                                                                                                     :iban ""
                                                                                                                                     :is_light false
                                                                                                                                     :label_user {:avatar {}
                                                                                                                                                  :country ""
                                                                                                                                                  :display_name ""
                                                                                                                                                  :public_nick_name ""
                                                                                                                                                  :uuid ""}
                                                                                                                                     :merchant_category_code ""
                                                                                                                                     :swift_account_number ""
                                                                                                                                     :swift_bic ""
                                                                                                                                     :transferwise_account_number ""
                                                                                                                                     :transferwise_bank_code ""}
                                                                                                                     :created ""
                                                                                                                     :description ""
                                                                                                                     :draft_share_invite_bank_id 0
                                                                                                                     :end_date ""
                                                                                                                     :id 0
                                                                                                                     :monetary_account_id 0
                                                                                                                     :relation_user {:counter_label_user {}
                                                                                                                                     :counter_user_id ""
                                                                                                                                     :counter_user_status ""
                                                                                                                                     :label_user {}
                                                                                                                                     :relationship ""
                                                                                                                                     :status ""
                                                                                                                                     :user_id ""
                                                                                                                                     :user_status ""}
                                                                                                                     :share_detail {:draft_payment {:make_draft_payments false
                                                                                                                                                    :view_balance false
                                                                                                                                                    :view_new_events false
                                                                                                                                                    :view_old_events false}
                                                                                                                                    :payment {:make_draft_payments false
                                                                                                                                              :make_payments false
                                                                                                                                              :view_balance false
                                                                                                                                              :view_new_events false
                                                                                                                                              :view_old_events false}
                                                                                                                                    :read_only {:view_balance false
                                                                                                                                                :view_new_events false
                                                                                                                                                :view_old_events false}}
                                                                                                                     :share_type ""
                                                                                                                     :start_date ""
                                                                                                                     :status ""
                                                                                                                     :updated ""
                                                                                                                     :user_alias_cancelled {}}})
require "http/client"

url = "{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"access_type\": \"\",\n  \"card_id\": 0,\n  \"counter_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relation_user\": {\n    \"counter_label_user\": {},\n    \"counter_user_id\": \"\",\n    \"counter_user_status\": \"\",\n    \"label_user\": {},\n    \"relationship\": \"\",\n    \"status\": \"\",\n    \"user_id\": \"\",\n    \"user_status\": \"\"\n  },\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"updated\": \"\",\n  \"user_alias_cancelled\": {}\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"access_type\": \"\",\n  \"card_id\": 0,\n  \"counter_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relation_user\": {\n    \"counter_label_user\": {},\n    \"counter_user_id\": \"\",\n    \"counter_user_status\": \"\",\n    \"label_user\": {},\n    \"relationship\": \"\",\n    \"status\": \"\",\n    \"user_id\": \"\",\n    \"user_status\": \"\"\n  },\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"updated\": \"\",\n  \"user_alias_cancelled\": {}\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"access_type\": \"\",\n  \"card_id\": 0,\n  \"counter_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relation_user\": {\n    \"counter_label_user\": {},\n    \"counter_user_id\": \"\",\n    \"counter_user_status\": \"\",\n    \"label_user\": {},\n    \"relationship\": \"\",\n    \"status\": \"\",\n    \"user_id\": \"\",\n    \"user_status\": \"\"\n  },\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"updated\": \"\",\n  \"user_alias_cancelled\": {}\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId"

	payload := strings.NewReader("{\n  \"access_type\": \"\",\n  \"card_id\": 0,\n  \"counter_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relation_user\": {\n    \"counter_label_user\": {},\n    \"counter_user_id\": \"\",\n    \"counter_user_status\": \"\",\n    \"label_user\": {},\n    \"relationship\": \"\",\n    \"status\": \"\",\n    \"user_id\": \"\",\n    \"user_status\": \"\"\n  },\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"updated\": \"\",\n  \"user_alias_cancelled\": {}\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/share-invite-monetary-account-response/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 1724

{
  "access_type": "",
  "card_id": 0,
  "counter_alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "created": "",
  "description": "",
  "draft_share_invite_bank_id": 0,
  "end_date": "",
  "id": 0,
  "monetary_account_id": 0,
  "relation_user": {
    "counter_label_user": {},
    "counter_user_id": "",
    "counter_user_status": "",
    "label_user": {},
    "relationship": "",
    "status": "",
    "user_id": "",
    "user_status": ""
  },
  "share_detail": {
    "draft_payment": {
      "make_draft_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "payment": {
      "make_draft_payments": false,
      "make_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "read_only": {
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    }
  },
  "share_type": "",
  "start_date": "",
  "status": "",
  "updated": "",
  "user_alias_cancelled": {}
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"access_type\": \"\",\n  \"card_id\": 0,\n  \"counter_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relation_user\": {\n    \"counter_label_user\": {},\n    \"counter_user_id\": \"\",\n    \"counter_user_status\": \"\",\n    \"label_user\": {},\n    \"relationship\": \"\",\n    \"status\": \"\",\n    \"user_id\": \"\",\n    \"user_status\": \"\"\n  },\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"updated\": \"\",\n  \"user_alias_cancelled\": {}\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"access_type\": \"\",\n  \"card_id\": 0,\n  \"counter_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relation_user\": {\n    \"counter_label_user\": {},\n    \"counter_user_id\": \"\",\n    \"counter_user_status\": \"\",\n    \"label_user\": {},\n    \"relationship\": \"\",\n    \"status\": \"\",\n    \"user_id\": \"\",\n    \"user_status\": \"\"\n  },\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"updated\": \"\",\n  \"user_alias_cancelled\": {}\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"access_type\": \"\",\n  \"card_id\": 0,\n  \"counter_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relation_user\": {\n    \"counter_label_user\": {},\n    \"counter_user_id\": \"\",\n    \"counter_user_status\": \"\",\n    \"label_user\": {},\n    \"relationship\": \"\",\n    \"status\": \"\",\n    \"user_id\": \"\",\n    \"user_status\": \"\"\n  },\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"updated\": \"\",\n  \"user_alias_cancelled\": {}\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"access_type\": \"\",\n  \"card_id\": 0,\n  \"counter_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relation_user\": {\n    \"counter_label_user\": {},\n    \"counter_user_id\": \"\",\n    \"counter_user_status\": \"\",\n    \"label_user\": {},\n    \"relationship\": \"\",\n    \"status\": \"\",\n    \"user_id\": \"\",\n    \"user_status\": \"\"\n  },\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"updated\": \"\",\n  \"user_alias_cancelled\": {}\n}")
  .asString();
const data = JSON.stringify({
  access_type: '',
  card_id: 0,
  counter_alias: {
    avatar: {
      anchor_uuid: '',
      image: [
        {
          attachment_public_uuid: '',
          content_type: '',
          height: 0,
          width: 0
        }
      ],
      style: '',
      uuid: ''
    },
    bunq_me: {
      name: '',
      service: '',
      type: '',
      value: ''
    },
    country: '',
    display_name: '',
    iban: '',
    is_light: false,
    label_user: {
      avatar: {},
      country: '',
      display_name: '',
      public_nick_name: '',
      uuid: ''
    },
    merchant_category_code: '',
    swift_account_number: '',
    swift_bic: '',
    transferwise_account_number: '',
    transferwise_bank_code: ''
  },
  created: '',
  description: '',
  draft_share_invite_bank_id: 0,
  end_date: '',
  id: 0,
  monetary_account_id: 0,
  relation_user: {
    counter_label_user: {},
    counter_user_id: '',
    counter_user_status: '',
    label_user: {},
    relationship: '',
    status: '',
    user_id: '',
    user_status: ''
  },
  share_detail: {
    draft_payment: {
      make_draft_payments: false,
      view_balance: false,
      view_new_events: false,
      view_old_events: false
    },
    payment: {
      make_draft_payments: false,
      make_payments: false,
      view_balance: false,
      view_new_events: false,
      view_old_events: false
    },
    read_only: {
      view_balance: false,
      view_new_events: false,
      view_old_events: false
    }
  },
  share_type: '',
  start_date: '',
  status: '',
  updated: '',
  user_alias_cancelled: {}
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    access_type: '',
    card_id: 0,
    counter_alias: {
      avatar: {
        anchor_uuid: '',
        image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
        style: '',
        uuid: ''
      },
      bunq_me: {name: '', service: '', type: '', value: ''},
      country: '',
      display_name: '',
      iban: '',
      is_light: false,
      label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
      merchant_category_code: '',
      swift_account_number: '',
      swift_bic: '',
      transferwise_account_number: '',
      transferwise_bank_code: ''
    },
    created: '',
    description: '',
    draft_share_invite_bank_id: 0,
    end_date: '',
    id: 0,
    monetary_account_id: 0,
    relation_user: {
      counter_label_user: {},
      counter_user_id: '',
      counter_user_status: '',
      label_user: {},
      relationship: '',
      status: '',
      user_id: '',
      user_status: ''
    },
    share_detail: {
      draft_payment: {
        make_draft_payments: false,
        view_balance: false,
        view_new_events: false,
        view_old_events: false
      },
      payment: {
        make_draft_payments: false,
        make_payments: false,
        view_balance: false,
        view_new_events: false,
        view_old_events: false
      },
      read_only: {view_balance: false, view_new_events: false, view_old_events: false}
    },
    share_type: '',
    start_date: '',
    status: '',
    updated: '',
    user_alias_cancelled: {}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"access_type":"","card_id":0,"counter_alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"created":"","description":"","draft_share_invite_bank_id":0,"end_date":"","id":0,"monetary_account_id":0,"relation_user":{"counter_label_user":{},"counter_user_id":"","counter_user_status":"","label_user":{},"relationship":"","status":"","user_id":"","user_status":""},"share_detail":{"draft_payment":{"make_draft_payments":false,"view_balance":false,"view_new_events":false,"view_old_events":false},"payment":{"make_draft_payments":false,"make_payments":false,"view_balance":false,"view_new_events":false,"view_old_events":false},"read_only":{"view_balance":false,"view_new_events":false,"view_old_events":false}},"share_type":"","start_date":"","status":"","updated":"","user_alias_cancelled":{}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "access_type": "",\n  "card_id": 0,\n  "counter_alias": {\n    "avatar": {\n      "anchor_uuid": "",\n      "image": [\n        {\n          "attachment_public_uuid": "",\n          "content_type": "",\n          "height": 0,\n          "width": 0\n        }\n      ],\n      "style": "",\n      "uuid": ""\n    },\n    "bunq_me": {\n      "name": "",\n      "service": "",\n      "type": "",\n      "value": ""\n    },\n    "country": "",\n    "display_name": "",\n    "iban": "",\n    "is_light": false,\n    "label_user": {\n      "avatar": {},\n      "country": "",\n      "display_name": "",\n      "public_nick_name": "",\n      "uuid": ""\n    },\n    "merchant_category_code": "",\n    "swift_account_number": "",\n    "swift_bic": "",\n    "transferwise_account_number": "",\n    "transferwise_bank_code": ""\n  },\n  "created": "",\n  "description": "",\n  "draft_share_invite_bank_id": 0,\n  "end_date": "",\n  "id": 0,\n  "monetary_account_id": 0,\n  "relation_user": {\n    "counter_label_user": {},\n    "counter_user_id": "",\n    "counter_user_status": "",\n    "label_user": {},\n    "relationship": "",\n    "status": "",\n    "user_id": "",\n    "user_status": ""\n  },\n  "share_detail": {\n    "draft_payment": {\n      "make_draft_payments": false,\n      "view_balance": false,\n      "view_new_events": false,\n      "view_old_events": false\n    },\n    "payment": {\n      "make_draft_payments": false,\n      "make_payments": false,\n      "view_balance": false,\n      "view_new_events": false,\n      "view_old_events": false\n    },\n    "read_only": {\n      "view_balance": false,\n      "view_new_events": false,\n      "view_old_events": false\n    }\n  },\n  "share_type": "",\n  "start_date": "",\n  "status": "",\n  "updated": "",\n  "user_alias_cancelled": {}\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"access_type\": \"\",\n  \"card_id\": 0,\n  \"counter_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relation_user\": {\n    \"counter_label_user\": {},\n    \"counter_user_id\": \"\",\n    \"counter_user_status\": \"\",\n    \"label_user\": {},\n    \"relationship\": \"\",\n    \"status\": \"\",\n    \"user_id\": \"\",\n    \"user_status\": \"\"\n  },\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"updated\": \"\",\n  \"user_alias_cancelled\": {}\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/share-invite-monetary-account-response/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  access_type: '',
  card_id: 0,
  counter_alias: {
    avatar: {
      anchor_uuid: '',
      image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
      style: '',
      uuid: ''
    },
    bunq_me: {name: '', service: '', type: '', value: ''},
    country: '',
    display_name: '',
    iban: '',
    is_light: false,
    label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
    merchant_category_code: '',
    swift_account_number: '',
    swift_bic: '',
    transferwise_account_number: '',
    transferwise_bank_code: ''
  },
  created: '',
  description: '',
  draft_share_invite_bank_id: 0,
  end_date: '',
  id: 0,
  monetary_account_id: 0,
  relation_user: {
    counter_label_user: {},
    counter_user_id: '',
    counter_user_status: '',
    label_user: {},
    relationship: '',
    status: '',
    user_id: '',
    user_status: ''
  },
  share_detail: {
    draft_payment: {
      make_draft_payments: false,
      view_balance: false,
      view_new_events: false,
      view_old_events: false
    },
    payment: {
      make_draft_payments: false,
      make_payments: false,
      view_balance: false,
      view_new_events: false,
      view_old_events: false
    },
    read_only: {view_balance: false, view_new_events: false, view_old_events: false}
  },
  share_type: '',
  start_date: '',
  status: '',
  updated: '',
  user_alias_cancelled: {}
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    access_type: '',
    card_id: 0,
    counter_alias: {
      avatar: {
        anchor_uuid: '',
        image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
        style: '',
        uuid: ''
      },
      bunq_me: {name: '', service: '', type: '', value: ''},
      country: '',
      display_name: '',
      iban: '',
      is_light: false,
      label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
      merchant_category_code: '',
      swift_account_number: '',
      swift_bic: '',
      transferwise_account_number: '',
      transferwise_bank_code: ''
    },
    created: '',
    description: '',
    draft_share_invite_bank_id: 0,
    end_date: '',
    id: 0,
    monetary_account_id: 0,
    relation_user: {
      counter_label_user: {},
      counter_user_id: '',
      counter_user_status: '',
      label_user: {},
      relationship: '',
      status: '',
      user_id: '',
      user_status: ''
    },
    share_detail: {
      draft_payment: {
        make_draft_payments: false,
        view_balance: false,
        view_new_events: false,
        view_old_events: false
      },
      payment: {
        make_draft_payments: false,
        make_payments: false,
        view_balance: false,
        view_new_events: false,
        view_old_events: false
      },
      read_only: {view_balance: false, view_new_events: false, view_old_events: false}
    },
    share_type: '',
    start_date: '',
    status: '',
    updated: '',
    user_alias_cancelled: {}
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  access_type: '',
  card_id: 0,
  counter_alias: {
    avatar: {
      anchor_uuid: '',
      image: [
        {
          attachment_public_uuid: '',
          content_type: '',
          height: 0,
          width: 0
        }
      ],
      style: '',
      uuid: ''
    },
    bunq_me: {
      name: '',
      service: '',
      type: '',
      value: ''
    },
    country: '',
    display_name: '',
    iban: '',
    is_light: false,
    label_user: {
      avatar: {},
      country: '',
      display_name: '',
      public_nick_name: '',
      uuid: ''
    },
    merchant_category_code: '',
    swift_account_number: '',
    swift_bic: '',
    transferwise_account_number: '',
    transferwise_bank_code: ''
  },
  created: '',
  description: '',
  draft_share_invite_bank_id: 0,
  end_date: '',
  id: 0,
  monetary_account_id: 0,
  relation_user: {
    counter_label_user: {},
    counter_user_id: '',
    counter_user_status: '',
    label_user: {},
    relationship: '',
    status: '',
    user_id: '',
    user_status: ''
  },
  share_detail: {
    draft_payment: {
      make_draft_payments: false,
      view_balance: false,
      view_new_events: false,
      view_old_events: false
    },
    payment: {
      make_draft_payments: false,
      make_payments: false,
      view_balance: false,
      view_new_events: false,
      view_old_events: false
    },
    read_only: {
      view_balance: false,
      view_new_events: false,
      view_old_events: false
    }
  },
  share_type: '',
  start_date: '',
  status: '',
  updated: '',
  user_alias_cancelled: {}
});

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}}/user/:userID/share-invite-monetary-account-response/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    access_type: '',
    card_id: 0,
    counter_alias: {
      avatar: {
        anchor_uuid: '',
        image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
        style: '',
        uuid: ''
      },
      bunq_me: {name: '', service: '', type: '', value: ''},
      country: '',
      display_name: '',
      iban: '',
      is_light: false,
      label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
      merchant_category_code: '',
      swift_account_number: '',
      swift_bic: '',
      transferwise_account_number: '',
      transferwise_bank_code: ''
    },
    created: '',
    description: '',
    draft_share_invite_bank_id: 0,
    end_date: '',
    id: 0,
    monetary_account_id: 0,
    relation_user: {
      counter_label_user: {},
      counter_user_id: '',
      counter_user_status: '',
      label_user: {},
      relationship: '',
      status: '',
      user_id: '',
      user_status: ''
    },
    share_detail: {
      draft_payment: {
        make_draft_payments: false,
        view_balance: false,
        view_new_events: false,
        view_old_events: false
      },
      payment: {
        make_draft_payments: false,
        make_payments: false,
        view_balance: false,
        view_new_events: false,
        view_old_events: false
      },
      read_only: {view_balance: false, view_new_events: false, view_old_events: false}
    },
    share_type: '',
    start_date: '',
    status: '',
    updated: '',
    user_alias_cancelled: {}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"access_type":"","card_id":0,"counter_alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"created":"","description":"","draft_share_invite_bank_id":0,"end_date":"","id":0,"monetary_account_id":0,"relation_user":{"counter_label_user":{},"counter_user_id":"","counter_user_status":"","label_user":{},"relationship":"","status":"","user_id":"","user_status":""},"share_detail":{"draft_payment":{"make_draft_payments":false,"view_balance":false,"view_new_events":false,"view_old_events":false},"payment":{"make_draft_payments":false,"make_payments":false,"view_balance":false,"view_new_events":false,"view_old_events":false},"read_only":{"view_balance":false,"view_new_events":false,"view_old_events":false}},"share_type":"","start_date":"","status":"","updated":"","user_alias_cancelled":{}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"access_type": @"",
                              @"card_id": @0,
                              @"counter_alias": @{ @"avatar": @{ @"anchor_uuid": @"", @"image": @[ @{ @"attachment_public_uuid": @"", @"content_type": @"", @"height": @0, @"width": @0 } ], @"style": @"", @"uuid": @"" }, @"bunq_me": @{ @"name": @"", @"service": @"", @"type": @"", @"value": @"" }, @"country": @"", @"display_name": @"", @"iban": @"", @"is_light": @NO, @"label_user": @{ @"avatar": @{  }, @"country": @"", @"display_name": @"", @"public_nick_name": @"", @"uuid": @"" }, @"merchant_category_code": @"", @"swift_account_number": @"", @"swift_bic": @"", @"transferwise_account_number": @"", @"transferwise_bank_code": @"" },
                              @"created": @"",
                              @"description": @"",
                              @"draft_share_invite_bank_id": @0,
                              @"end_date": @"",
                              @"id": @0,
                              @"monetary_account_id": @0,
                              @"relation_user": @{ @"counter_label_user": @{  }, @"counter_user_id": @"", @"counter_user_status": @"", @"label_user": @{  }, @"relationship": @"", @"status": @"", @"user_id": @"", @"user_status": @"" },
                              @"share_detail": @{ @"draft_payment": @{ @"make_draft_payments": @NO, @"view_balance": @NO, @"view_new_events": @NO, @"view_old_events": @NO }, @"payment": @{ @"make_draft_payments": @NO, @"make_payments": @NO, @"view_balance": @NO, @"view_new_events": @NO, @"view_old_events": @NO }, @"read_only": @{ @"view_balance": @NO, @"view_new_events": @NO, @"view_old_events": @NO } },
                              @"share_type": @"",
                              @"start_date": @"",
                              @"status": @"",
                              @"updated": @"",
                              @"user_alias_cancelled": @{  } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"access_type\": \"\",\n  \"card_id\": 0,\n  \"counter_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relation_user\": {\n    \"counter_label_user\": {},\n    \"counter_user_id\": \"\",\n    \"counter_user_status\": \"\",\n    \"label_user\": {},\n    \"relationship\": \"\",\n    \"status\": \"\",\n    \"user_id\": \"\",\n    \"user_status\": \"\"\n  },\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"updated\": \"\",\n  \"user_alias_cancelled\": {}\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'access_type' => '',
    'card_id' => 0,
    'counter_alias' => [
        'avatar' => [
                'anchor_uuid' => '',
                'image' => [
                                [
                                                                'attachment_public_uuid' => '',
                                                                'content_type' => '',
                                                                'height' => 0,
                                                                'width' => 0
                                ]
                ],
                'style' => '',
                'uuid' => ''
        ],
        'bunq_me' => [
                'name' => '',
                'service' => '',
                'type' => '',
                'value' => ''
        ],
        'country' => '',
        'display_name' => '',
        'iban' => '',
        'is_light' => null,
        'label_user' => [
                'avatar' => [
                                
                ],
                'country' => '',
                'display_name' => '',
                'public_nick_name' => '',
                'uuid' => ''
        ],
        'merchant_category_code' => '',
        'swift_account_number' => '',
        'swift_bic' => '',
        'transferwise_account_number' => '',
        'transferwise_bank_code' => ''
    ],
    'created' => '',
    'description' => '',
    'draft_share_invite_bank_id' => 0,
    'end_date' => '',
    'id' => 0,
    'monetary_account_id' => 0,
    'relation_user' => [
        'counter_label_user' => [
                
        ],
        'counter_user_id' => '',
        'counter_user_status' => '',
        'label_user' => [
                
        ],
        'relationship' => '',
        'status' => '',
        'user_id' => '',
        'user_status' => ''
    ],
    'share_detail' => [
        'draft_payment' => [
                'make_draft_payments' => null,
                'view_balance' => null,
                'view_new_events' => null,
                'view_old_events' => null
        ],
        'payment' => [
                'make_draft_payments' => null,
                'make_payments' => null,
                'view_balance' => null,
                'view_new_events' => null,
                'view_old_events' => null
        ],
        'read_only' => [
                'view_balance' => null,
                'view_new_events' => null,
                'view_old_events' => null
        ]
    ],
    'share_type' => '',
    'start_date' => '',
    'status' => '',
    'updated' => '',
    'user_alias_cancelled' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId', [
  'body' => '{
  "access_type": "",
  "card_id": 0,
  "counter_alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "created": "",
  "description": "",
  "draft_share_invite_bank_id": 0,
  "end_date": "",
  "id": 0,
  "monetary_account_id": 0,
  "relation_user": {
    "counter_label_user": {},
    "counter_user_id": "",
    "counter_user_status": "",
    "label_user": {},
    "relationship": "",
    "status": "",
    "user_id": "",
    "user_status": ""
  },
  "share_detail": {
    "draft_payment": {
      "make_draft_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "payment": {
      "make_draft_payments": false,
      "make_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "read_only": {
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    }
  },
  "share_type": "",
  "start_date": "",
  "status": "",
  "updated": "",
  "user_alias_cancelled": {}
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'access_type' => '',
  'card_id' => 0,
  'counter_alias' => [
    'avatar' => [
        'anchor_uuid' => '',
        'image' => [
                [
                                'attachment_public_uuid' => '',
                                'content_type' => '',
                                'height' => 0,
                                'width' => 0
                ]
        ],
        'style' => '',
        'uuid' => ''
    ],
    'bunq_me' => [
        'name' => '',
        'service' => '',
        'type' => '',
        'value' => ''
    ],
    'country' => '',
    'display_name' => '',
    'iban' => '',
    'is_light' => null,
    'label_user' => [
        'avatar' => [
                
        ],
        'country' => '',
        'display_name' => '',
        'public_nick_name' => '',
        'uuid' => ''
    ],
    'merchant_category_code' => '',
    'swift_account_number' => '',
    'swift_bic' => '',
    'transferwise_account_number' => '',
    'transferwise_bank_code' => ''
  ],
  'created' => '',
  'description' => '',
  'draft_share_invite_bank_id' => 0,
  'end_date' => '',
  'id' => 0,
  'monetary_account_id' => 0,
  'relation_user' => [
    'counter_label_user' => [
        
    ],
    'counter_user_id' => '',
    'counter_user_status' => '',
    'label_user' => [
        
    ],
    'relationship' => '',
    'status' => '',
    'user_id' => '',
    'user_status' => ''
  ],
  'share_detail' => [
    'draft_payment' => [
        'make_draft_payments' => null,
        'view_balance' => null,
        'view_new_events' => null,
        'view_old_events' => null
    ],
    'payment' => [
        'make_draft_payments' => null,
        'make_payments' => null,
        'view_balance' => null,
        'view_new_events' => null,
        'view_old_events' => null
    ],
    'read_only' => [
        'view_balance' => null,
        'view_new_events' => null,
        'view_old_events' => null
    ]
  ],
  'share_type' => '',
  'start_date' => '',
  'status' => '',
  'updated' => '',
  'user_alias_cancelled' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'access_type' => '',
  'card_id' => 0,
  'counter_alias' => [
    'avatar' => [
        'anchor_uuid' => '',
        'image' => [
                [
                                'attachment_public_uuid' => '',
                                'content_type' => '',
                                'height' => 0,
                                'width' => 0
                ]
        ],
        'style' => '',
        'uuid' => ''
    ],
    'bunq_me' => [
        'name' => '',
        'service' => '',
        'type' => '',
        'value' => ''
    ],
    'country' => '',
    'display_name' => '',
    'iban' => '',
    'is_light' => null,
    'label_user' => [
        'avatar' => [
                
        ],
        'country' => '',
        'display_name' => '',
        'public_nick_name' => '',
        'uuid' => ''
    ],
    'merchant_category_code' => '',
    'swift_account_number' => '',
    'swift_bic' => '',
    'transferwise_account_number' => '',
    'transferwise_bank_code' => ''
  ],
  'created' => '',
  'description' => '',
  'draft_share_invite_bank_id' => 0,
  'end_date' => '',
  'id' => 0,
  'monetary_account_id' => 0,
  'relation_user' => [
    'counter_label_user' => [
        
    ],
    'counter_user_id' => '',
    'counter_user_status' => '',
    'label_user' => [
        
    ],
    'relationship' => '',
    'status' => '',
    'user_id' => '',
    'user_status' => ''
  ],
  'share_detail' => [
    'draft_payment' => [
        'make_draft_payments' => null,
        'view_balance' => null,
        'view_new_events' => null,
        'view_old_events' => null
    ],
    'payment' => [
        'make_draft_payments' => null,
        'make_payments' => null,
        'view_balance' => null,
        'view_new_events' => null,
        'view_old_events' => null
    ],
    'read_only' => [
        'view_balance' => null,
        'view_new_events' => null,
        'view_old_events' => null
    ]
  ],
  'share_type' => '',
  'start_date' => '',
  'status' => '',
  'updated' => '',
  'user_alias_cancelled' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "access_type": "",
  "card_id": 0,
  "counter_alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "created": "",
  "description": "",
  "draft_share_invite_bank_id": 0,
  "end_date": "",
  "id": 0,
  "monetary_account_id": 0,
  "relation_user": {
    "counter_label_user": {},
    "counter_user_id": "",
    "counter_user_status": "",
    "label_user": {},
    "relationship": "",
    "status": "",
    "user_id": "",
    "user_status": ""
  },
  "share_detail": {
    "draft_payment": {
      "make_draft_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "payment": {
      "make_draft_payments": false,
      "make_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "read_only": {
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    }
  },
  "share_type": "",
  "start_date": "",
  "status": "",
  "updated": "",
  "user_alias_cancelled": {}
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "access_type": "",
  "card_id": 0,
  "counter_alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "created": "",
  "description": "",
  "draft_share_invite_bank_id": 0,
  "end_date": "",
  "id": 0,
  "monetary_account_id": 0,
  "relation_user": {
    "counter_label_user": {},
    "counter_user_id": "",
    "counter_user_status": "",
    "label_user": {},
    "relationship": "",
    "status": "",
    "user_id": "",
    "user_status": ""
  },
  "share_detail": {
    "draft_payment": {
      "make_draft_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "payment": {
      "make_draft_payments": false,
      "make_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "read_only": {
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    }
  },
  "share_type": "",
  "start_date": "",
  "status": "",
  "updated": "",
  "user_alias_cancelled": {}
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"access_type\": \"\",\n  \"card_id\": 0,\n  \"counter_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relation_user\": {\n    \"counter_label_user\": {},\n    \"counter_user_id\": \"\",\n    \"counter_user_status\": \"\",\n    \"label_user\": {},\n    \"relationship\": \"\",\n    \"status\": \"\",\n    \"user_id\": \"\",\n    \"user_status\": \"\"\n  },\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"updated\": \"\",\n  \"user_alias_cancelled\": {}\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/share-invite-monetary-account-response/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId"

payload = {
    "access_type": "",
    "card_id": 0,
    "counter_alias": {
        "avatar": {
            "anchor_uuid": "",
            "image": [
                {
                    "attachment_public_uuid": "",
                    "content_type": "",
                    "height": 0,
                    "width": 0
                }
            ],
            "style": "",
            "uuid": ""
        },
        "bunq_me": {
            "name": "",
            "service": "",
            "type": "",
            "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": False,
        "label_user": {
            "avatar": {},
            "country": "",
            "display_name": "",
            "public_nick_name": "",
            "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
    },
    "created": "",
    "description": "",
    "draft_share_invite_bank_id": 0,
    "end_date": "",
    "id": 0,
    "monetary_account_id": 0,
    "relation_user": {
        "counter_label_user": {},
        "counter_user_id": "",
        "counter_user_status": "",
        "label_user": {},
        "relationship": "",
        "status": "",
        "user_id": "",
        "user_status": ""
    },
    "share_detail": {
        "draft_payment": {
            "make_draft_payments": False,
            "view_balance": False,
            "view_new_events": False,
            "view_old_events": False
        },
        "payment": {
            "make_draft_payments": False,
            "make_payments": False,
            "view_balance": False,
            "view_new_events": False,
            "view_old_events": False
        },
        "read_only": {
            "view_balance": False,
            "view_new_events": False,
            "view_old_events": False
        }
    },
    "share_type": "",
    "start_date": "",
    "status": "",
    "updated": "",
    "user_alias_cancelled": {}
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId"

payload <- "{\n  \"access_type\": \"\",\n  \"card_id\": 0,\n  \"counter_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relation_user\": {\n    \"counter_label_user\": {},\n    \"counter_user_id\": \"\",\n    \"counter_user_status\": \"\",\n    \"label_user\": {},\n    \"relationship\": \"\",\n    \"status\": \"\",\n    \"user_id\": \"\",\n    \"user_status\": \"\"\n  },\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"updated\": \"\",\n  \"user_alias_cancelled\": {}\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"access_type\": \"\",\n  \"card_id\": 0,\n  \"counter_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relation_user\": {\n    \"counter_label_user\": {},\n    \"counter_user_id\": \"\",\n    \"counter_user_status\": \"\",\n    \"label_user\": {},\n    \"relationship\": \"\",\n    \"status\": \"\",\n    \"user_id\": \"\",\n    \"user_status\": \"\"\n  },\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"updated\": \"\",\n  \"user_alias_cancelled\": {}\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/share-invite-monetary-account-response/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"access_type\": \"\",\n  \"card_id\": 0,\n  \"counter_alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"created\": \"\",\n  \"description\": \"\",\n  \"draft_share_invite_bank_id\": 0,\n  \"end_date\": \"\",\n  \"id\": 0,\n  \"monetary_account_id\": 0,\n  \"relation_user\": {\n    \"counter_label_user\": {},\n    \"counter_user_id\": \"\",\n    \"counter_user_status\": \"\",\n    \"label_user\": {},\n    \"relationship\": \"\",\n    \"status\": \"\",\n    \"user_id\": \"\",\n    \"user_status\": \"\"\n  },\n  \"share_detail\": {\n    \"draft_payment\": {\n      \"make_draft_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"payment\": {\n      \"make_draft_payments\": false,\n      \"make_payments\": false,\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    },\n    \"read_only\": {\n      \"view_balance\": false,\n      \"view_new_events\": false,\n      \"view_old_events\": false\n    }\n  },\n  \"share_type\": \"\",\n  \"start_date\": \"\",\n  \"status\": \"\",\n  \"updated\": \"\",\n  \"user_alias_cancelled\": {}\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId";

    let payload = json!({
        "access_type": "",
        "card_id": 0,
        "counter_alias": json!({
            "avatar": json!({
                "anchor_uuid": "",
                "image": (
                    json!({
                        "attachment_public_uuid": "",
                        "content_type": "",
                        "height": 0,
                        "width": 0
                    })
                ),
                "style": "",
                "uuid": ""
            }),
            "bunq_me": json!({
                "name": "",
                "service": "",
                "type": "",
                "value": ""
            }),
            "country": "",
            "display_name": "",
            "iban": "",
            "is_light": false,
            "label_user": json!({
                "avatar": json!({}),
                "country": "",
                "display_name": "",
                "public_nick_name": "",
                "uuid": ""
            }),
            "merchant_category_code": "",
            "swift_account_number": "",
            "swift_bic": "",
            "transferwise_account_number": "",
            "transferwise_bank_code": ""
        }),
        "created": "",
        "description": "",
        "draft_share_invite_bank_id": 0,
        "end_date": "",
        "id": 0,
        "monetary_account_id": 0,
        "relation_user": json!({
            "counter_label_user": json!({}),
            "counter_user_id": "",
            "counter_user_status": "",
            "label_user": json!({}),
            "relationship": "",
            "status": "",
            "user_id": "",
            "user_status": ""
        }),
        "share_detail": json!({
            "draft_payment": json!({
                "make_draft_payments": false,
                "view_balance": false,
                "view_new_events": false,
                "view_old_events": false
            }),
            "payment": json!({
                "make_draft_payments": false,
                "make_payments": false,
                "view_balance": false,
                "view_new_events": false,
                "view_old_events": false
            }),
            "read_only": json!({
                "view_balance": false,
                "view_new_events": false,
                "view_old_events": false
            })
        }),
        "share_type": "",
        "start_date": "",
        "status": "",
        "updated": "",
        "user_alias_cancelled": json!({})
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "access_type": "",
  "card_id": 0,
  "counter_alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "created": "",
  "description": "",
  "draft_share_invite_bank_id": 0,
  "end_date": "",
  "id": 0,
  "monetary_account_id": 0,
  "relation_user": {
    "counter_label_user": {},
    "counter_user_id": "",
    "counter_user_status": "",
    "label_user": {},
    "relationship": "",
    "status": "",
    "user_id": "",
    "user_status": ""
  },
  "share_detail": {
    "draft_payment": {
      "make_draft_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "payment": {
      "make_draft_payments": false,
      "make_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "read_only": {
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    }
  },
  "share_type": "",
  "start_date": "",
  "status": "",
  "updated": "",
  "user_alias_cancelled": {}
}'
echo '{
  "access_type": "",
  "card_id": 0,
  "counter_alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "created": "",
  "description": "",
  "draft_share_invite_bank_id": 0,
  "end_date": "",
  "id": 0,
  "monetary_account_id": 0,
  "relation_user": {
    "counter_label_user": {},
    "counter_user_id": "",
    "counter_user_status": "",
    "label_user": {},
    "relationship": "",
    "status": "",
    "user_id": "",
    "user_status": ""
  },
  "share_detail": {
    "draft_payment": {
      "make_draft_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "payment": {
      "make_draft_payments": false,
      "make_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    },
    "read_only": {
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    }
  },
  "share_type": "",
  "start_date": "",
  "status": "",
  "updated": "",
  "user_alias_cancelled": {}
}' |  \
  http PUT {{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "access_type": "",\n  "card_id": 0,\n  "counter_alias": {\n    "avatar": {\n      "anchor_uuid": "",\n      "image": [\n        {\n          "attachment_public_uuid": "",\n          "content_type": "",\n          "height": 0,\n          "width": 0\n        }\n      ],\n      "style": "",\n      "uuid": ""\n    },\n    "bunq_me": {\n      "name": "",\n      "service": "",\n      "type": "",\n      "value": ""\n    },\n    "country": "",\n    "display_name": "",\n    "iban": "",\n    "is_light": false,\n    "label_user": {\n      "avatar": {},\n      "country": "",\n      "display_name": "",\n      "public_nick_name": "",\n      "uuid": ""\n    },\n    "merchant_category_code": "",\n    "swift_account_number": "",\n    "swift_bic": "",\n    "transferwise_account_number": "",\n    "transferwise_bank_code": ""\n  },\n  "created": "",\n  "description": "",\n  "draft_share_invite_bank_id": 0,\n  "end_date": "",\n  "id": 0,\n  "monetary_account_id": 0,\n  "relation_user": {\n    "counter_label_user": {},\n    "counter_user_id": "",\n    "counter_user_status": "",\n    "label_user": {},\n    "relationship": "",\n    "status": "",\n    "user_id": "",\n    "user_status": ""\n  },\n  "share_detail": {\n    "draft_payment": {\n      "make_draft_payments": false,\n      "view_balance": false,\n      "view_new_events": false,\n      "view_old_events": false\n    },\n    "payment": {\n      "make_draft_payments": false,\n      "make_payments": false,\n      "view_balance": false,\n      "view_new_events": false,\n      "view_old_events": false\n    },\n    "read_only": {\n      "view_balance": false,\n      "view_new_events": false,\n      "view_old_events": false\n    }\n  },\n  "share_type": "",\n  "start_date": "",\n  "status": "",\n  "updated": "",\n  "user_alias_cancelled": {}\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "access_type": "",
  "card_id": 0,
  "counter_alias": [
    "avatar": [
      "anchor_uuid": "",
      "image": [
        [
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        ]
      ],
      "style": "",
      "uuid": ""
    ],
    "bunq_me": [
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    ],
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": [
      "avatar": [],
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    ],
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  ],
  "created": "",
  "description": "",
  "draft_share_invite_bank_id": 0,
  "end_date": "",
  "id": 0,
  "monetary_account_id": 0,
  "relation_user": [
    "counter_label_user": [],
    "counter_user_id": "",
    "counter_user_status": "",
    "label_user": [],
    "relationship": "",
    "status": "",
    "user_id": "",
    "user_status": ""
  ],
  "share_detail": [
    "draft_payment": [
      "make_draft_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    ],
    "payment": [
      "make_draft_payments": false,
      "make_payments": false,
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    ],
    "read_only": [
      "view_balance": false,
      "view_new_events": false,
      "view_old_events": false
    ]
  ],
  "share_type": "",
  "start_date": "",
  "status": "",
  "updated": "",
  "user_alias_cancelled": []
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/share-invite-monetary-account-response/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_SofortMerchantTransaction_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction" {:headers {:user-agent ""
                                                                                                                                   :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_SofortMerchantTransaction_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:itemId" {:headers {:user-agent ""
                                                                                                                                           :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/sofort-merchant-transaction/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_Statement_for_User_MonetaryAccount_Event
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
eventID
BODY json

{}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement" {:headers {:user-agent ""
                                                                                                                                 :x-bunq-client-authentication ""}
                                                                                                                       :content-type :json})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement"

	payload := strings.NewReader("{}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 2

{}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{}")
  .asString();
const data = JSON.stringify({});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{  };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement', [
  'body' => '{}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement' -Method POST -Headers $headers -ContentType 'application/json' -Body '{}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement' -Method POST -Headers $headers -ContentType 'application/json' -Body '{}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement"

payload = {}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement"

payload <- "{}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement";

    let payload = json!({});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{}'
echo '{}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_Statement_for_User_MonetaryAccount_Event
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
eventID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:itemId" {:headers {:user-agent ""
                                                                                                                                        :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/event/:eventID/statement/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_SwitchServicePayment_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:itemId" {:headers {:user-agent ""
                                                                                                                                      :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/switch-service-payment/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_TokenQrRequestIdeal_for_User
{{baseUrl}}/user/:userID/token-qr-request-ideal
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
BODY json

{
  "token": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/token-qr-request-ideal");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"token\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/token-qr-request-ideal" {:headers {:user-agent ""
                                                                                          :x-bunq-client-authentication ""}
                                                                                :content-type :json
                                                                                :form-params {:token ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/token-qr-request-ideal"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"token\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/token-qr-request-ideal"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"token\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/token-qr-request-ideal");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"token\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/token-qr-request-ideal"

	payload := strings.NewReader("{\n  \"token\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/token-qr-request-ideal HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 17

{
  "token": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/token-qr-request-ideal")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"token\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/token-qr-request-ideal"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"token\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"token\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/token-qr-request-ideal")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/token-qr-request-ideal")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"token\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  token: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/token-qr-request-ideal');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/token-qr-request-ideal',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {token: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/token-qr-request-ideal';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"token":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/token-qr-request-ideal',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "token": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"token\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/token-qr-request-ideal")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/token-qr-request-ideal',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({token: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/token-qr-request-ideal',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {token: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/token-qr-request-ideal');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  token: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/token-qr-request-ideal',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {token: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/token-qr-request-ideal';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"token":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"token": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/token-qr-request-ideal"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/token-qr-request-ideal" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"token\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/token-qr-request-ideal",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'token' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/token-qr-request-ideal', [
  'body' => '{
  "token": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/token-qr-request-ideal');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'token' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'token' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/token-qr-request-ideal');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/token-qr-request-ideal' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "token": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/token-qr-request-ideal' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "token": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"token\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/token-qr-request-ideal", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/token-qr-request-ideal"

payload = { "token": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/token-qr-request-ideal"

payload <- "{\n  \"token\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/token-qr-request-ideal")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"token\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/token-qr-request-ideal') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"token\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/token-qr-request-ideal";

    let payload = json!({"token": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/token-qr-request-ideal \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "token": ""
}'
echo '{
  "token": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/token-qr-request-ideal \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "token": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/token-qr-request-ideal
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["token": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/token-qr-request-ideal")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_TokenQrRequestSofort_for_User
{{baseUrl}}/user/:userID/token-qr-request-sofort
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
BODY json

{
  "token": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/token-qr-request-sofort");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"token\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/token-qr-request-sofort" {:headers {:user-agent ""
                                                                                           :x-bunq-client-authentication ""}
                                                                                 :content-type :json
                                                                                 :form-params {:token ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/token-qr-request-sofort"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"token\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/token-qr-request-sofort"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"token\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/token-qr-request-sofort");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"token\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/token-qr-request-sofort"

	payload := strings.NewReader("{\n  \"token\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/token-qr-request-sofort HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 17

{
  "token": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/token-qr-request-sofort")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"token\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/token-qr-request-sofort"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"token\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"token\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/token-qr-request-sofort")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/token-qr-request-sofort")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"token\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  token: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/token-qr-request-sofort');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/token-qr-request-sofort',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {token: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/token-qr-request-sofort';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"token":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/token-qr-request-sofort',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "token": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"token\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/token-qr-request-sofort")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/token-qr-request-sofort',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({token: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/token-qr-request-sofort',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {token: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/token-qr-request-sofort');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  token: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/token-qr-request-sofort',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {token: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/token-qr-request-sofort';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"token":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"token": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/token-qr-request-sofort"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/token-qr-request-sofort" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"token\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/token-qr-request-sofort",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'token' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/token-qr-request-sofort', [
  'body' => '{
  "token": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/token-qr-request-sofort');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'token' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'token' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/token-qr-request-sofort');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/token-qr-request-sofort' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "token": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/token-qr-request-sofort' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "token": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"token\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/token-qr-request-sofort", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/token-qr-request-sofort"

payload = { "token": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/token-qr-request-sofort"

payload <- "{\n  \"token\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/token-qr-request-sofort")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"token\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/token-qr-request-sofort') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"token\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/token-qr-request-sofort";

    let payload = json!({"token": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/token-qr-request-sofort \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "token": ""
}'
echo '{
  "token": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/token-qr-request-sofort \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "token": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/token-qr-request-sofort
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["token": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/token-qr-request-sofort")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_TransferwiseCurrency_for_User
{{baseUrl}}/user/:userID/transferwise-currency
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/transferwise-currency");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/transferwise-currency" {:headers {:user-agent ""
                                                                                        :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/transferwise-currency"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/transferwise-currency"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/transferwise-currency");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/transferwise-currency"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/transferwise-currency HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/transferwise-currency")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/transferwise-currency"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/transferwise-currency")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/transferwise-currency")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/transferwise-currency');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/transferwise-currency',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/transferwise-currency';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/transferwise-currency',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/transferwise-currency")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/transferwise-currency',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/transferwise-currency',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/transferwise-currency');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/transferwise-currency',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/transferwise-currency';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/transferwise-currency"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/transferwise-currency" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/transferwise-currency",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/transferwise-currency', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/transferwise-currency');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/transferwise-currency');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/transferwise-currency' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/transferwise-currency' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/transferwise-currency", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/transferwise-currency"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/transferwise-currency"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/transferwise-currency")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/transferwise-currency') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/transferwise-currency";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/transferwise-currency \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/transferwise-currency \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/transferwise-currency
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/transferwise-currency")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_TransferwiseQuote_for_User
{{baseUrl}}/user/:userID/transferwise-quote
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
BODY json

{
  "amount_fee": {
    "currency": "",
    "value": ""
  },
  "amount_source": {},
  "amount_target": {},
  "created": "",
  "currency_source": "",
  "currency_target": "",
  "id": 0,
  "quote_id": "",
  "rate": "",
  "time_delivery_estimate": "",
  "time_expiry": "",
  "updated": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/transferwise-quote");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"amount_fee\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_source\": {},\n  \"amount_target\": {},\n  \"created\": \"\",\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"id\": 0,\n  \"quote_id\": \"\",\n  \"rate\": \"\",\n  \"time_delivery_estimate\": \"\",\n  \"time_expiry\": \"\",\n  \"updated\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/transferwise-quote" {:headers {:user-agent ""
                                                                                      :x-bunq-client-authentication ""}
                                                                            :content-type :json
                                                                            :form-params {:amount_fee {:currency ""
                                                                                                       :value ""}
                                                                                          :amount_source {}
                                                                                          :amount_target {}
                                                                                          :created ""
                                                                                          :currency_source ""
                                                                                          :currency_target ""
                                                                                          :id 0
                                                                                          :quote_id ""
                                                                                          :rate ""
                                                                                          :time_delivery_estimate ""
                                                                                          :time_expiry ""
                                                                                          :updated ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/transferwise-quote"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"amount_fee\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_source\": {},\n  \"amount_target\": {},\n  \"created\": \"\",\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"id\": 0,\n  \"quote_id\": \"\",\n  \"rate\": \"\",\n  \"time_delivery_estimate\": \"\",\n  \"time_expiry\": \"\",\n  \"updated\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/transferwise-quote"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"amount_fee\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_source\": {},\n  \"amount_target\": {},\n  \"created\": \"\",\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"id\": 0,\n  \"quote_id\": \"\",\n  \"rate\": \"\",\n  \"time_delivery_estimate\": \"\",\n  \"time_expiry\": \"\",\n  \"updated\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/transferwise-quote");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"amount_fee\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_source\": {},\n  \"amount_target\": {},\n  \"created\": \"\",\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"id\": 0,\n  \"quote_id\": \"\",\n  \"rate\": \"\",\n  \"time_delivery_estimate\": \"\",\n  \"time_expiry\": \"\",\n  \"updated\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/transferwise-quote"

	payload := strings.NewReader("{\n  \"amount_fee\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_source\": {},\n  \"amount_target\": {},\n  \"created\": \"\",\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"id\": 0,\n  \"quote_id\": \"\",\n  \"rate\": \"\",\n  \"time_delivery_estimate\": \"\",\n  \"time_expiry\": \"\",\n  \"updated\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/transferwise-quote HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 287

{
  "amount_fee": {
    "currency": "",
    "value": ""
  },
  "amount_source": {},
  "amount_target": {},
  "created": "",
  "currency_source": "",
  "currency_target": "",
  "id": 0,
  "quote_id": "",
  "rate": "",
  "time_delivery_estimate": "",
  "time_expiry": "",
  "updated": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/transferwise-quote")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"amount_fee\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_source\": {},\n  \"amount_target\": {},\n  \"created\": \"\",\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"id\": 0,\n  \"quote_id\": \"\",\n  \"rate\": \"\",\n  \"time_delivery_estimate\": \"\",\n  \"time_expiry\": \"\",\n  \"updated\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/transferwise-quote"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"amount_fee\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_source\": {},\n  \"amount_target\": {},\n  \"created\": \"\",\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"id\": 0,\n  \"quote_id\": \"\",\n  \"rate\": \"\",\n  \"time_delivery_estimate\": \"\",\n  \"time_expiry\": \"\",\n  \"updated\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"amount_fee\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_source\": {},\n  \"amount_target\": {},\n  \"created\": \"\",\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"id\": 0,\n  \"quote_id\": \"\",\n  \"rate\": \"\",\n  \"time_delivery_estimate\": \"\",\n  \"time_expiry\": \"\",\n  \"updated\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/transferwise-quote")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/transferwise-quote")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"amount_fee\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_source\": {},\n  \"amount_target\": {},\n  \"created\": \"\",\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"id\": 0,\n  \"quote_id\": \"\",\n  \"rate\": \"\",\n  \"time_delivery_estimate\": \"\",\n  \"time_expiry\": \"\",\n  \"updated\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  amount_fee: {
    currency: '',
    value: ''
  },
  amount_source: {},
  amount_target: {},
  created: '',
  currency_source: '',
  currency_target: '',
  id: 0,
  quote_id: '',
  rate: '',
  time_delivery_estimate: '',
  time_expiry: '',
  updated: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/transferwise-quote');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/transferwise-quote',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    amount_fee: {currency: '', value: ''},
    amount_source: {},
    amount_target: {},
    created: '',
    currency_source: '',
    currency_target: '',
    id: 0,
    quote_id: '',
    rate: '',
    time_delivery_estimate: '',
    time_expiry: '',
    updated: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/transferwise-quote';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"amount_fee":{"currency":"","value":""},"amount_source":{},"amount_target":{},"created":"","currency_source":"","currency_target":"","id":0,"quote_id":"","rate":"","time_delivery_estimate":"","time_expiry":"","updated":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/transferwise-quote',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "amount_fee": {\n    "currency": "",\n    "value": ""\n  },\n  "amount_source": {},\n  "amount_target": {},\n  "created": "",\n  "currency_source": "",\n  "currency_target": "",\n  "id": 0,\n  "quote_id": "",\n  "rate": "",\n  "time_delivery_estimate": "",\n  "time_expiry": "",\n  "updated": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"amount_fee\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_source\": {},\n  \"amount_target\": {},\n  \"created\": \"\",\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"id\": 0,\n  \"quote_id\": \"\",\n  \"rate\": \"\",\n  \"time_delivery_estimate\": \"\",\n  \"time_expiry\": \"\",\n  \"updated\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/transferwise-quote")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/transferwise-quote',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  amount_fee: {currency: '', value: ''},
  amount_source: {},
  amount_target: {},
  created: '',
  currency_source: '',
  currency_target: '',
  id: 0,
  quote_id: '',
  rate: '',
  time_delivery_estimate: '',
  time_expiry: '',
  updated: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/transferwise-quote',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    amount_fee: {currency: '', value: ''},
    amount_source: {},
    amount_target: {},
    created: '',
    currency_source: '',
    currency_target: '',
    id: 0,
    quote_id: '',
    rate: '',
    time_delivery_estimate: '',
    time_expiry: '',
    updated: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/transferwise-quote');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  amount_fee: {
    currency: '',
    value: ''
  },
  amount_source: {},
  amount_target: {},
  created: '',
  currency_source: '',
  currency_target: '',
  id: 0,
  quote_id: '',
  rate: '',
  time_delivery_estimate: '',
  time_expiry: '',
  updated: ''
});

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}}/user/:userID/transferwise-quote',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    amount_fee: {currency: '', value: ''},
    amount_source: {},
    amount_target: {},
    created: '',
    currency_source: '',
    currency_target: '',
    id: 0,
    quote_id: '',
    rate: '',
    time_delivery_estimate: '',
    time_expiry: '',
    updated: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/transferwise-quote';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"amount_fee":{"currency":"","value":""},"amount_source":{},"amount_target":{},"created":"","currency_source":"","currency_target":"","id":0,"quote_id":"","rate":"","time_delivery_estimate":"","time_expiry":"","updated":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"amount_fee": @{ @"currency": @"", @"value": @"" },
                              @"amount_source": @{  },
                              @"amount_target": @{  },
                              @"created": @"",
                              @"currency_source": @"",
                              @"currency_target": @"",
                              @"id": @0,
                              @"quote_id": @"",
                              @"rate": @"",
                              @"time_delivery_estimate": @"",
                              @"time_expiry": @"",
                              @"updated": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/transferwise-quote"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/transferwise-quote" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"amount_fee\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_source\": {},\n  \"amount_target\": {},\n  \"created\": \"\",\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"id\": 0,\n  \"quote_id\": \"\",\n  \"rate\": \"\",\n  \"time_delivery_estimate\": \"\",\n  \"time_expiry\": \"\",\n  \"updated\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/transferwise-quote",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'amount_fee' => [
        'currency' => '',
        'value' => ''
    ],
    'amount_source' => [
        
    ],
    'amount_target' => [
        
    ],
    'created' => '',
    'currency_source' => '',
    'currency_target' => '',
    'id' => 0,
    'quote_id' => '',
    'rate' => '',
    'time_delivery_estimate' => '',
    'time_expiry' => '',
    'updated' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/transferwise-quote', [
  'body' => '{
  "amount_fee": {
    "currency": "",
    "value": ""
  },
  "amount_source": {},
  "amount_target": {},
  "created": "",
  "currency_source": "",
  "currency_target": "",
  "id": 0,
  "quote_id": "",
  "rate": "",
  "time_delivery_estimate": "",
  "time_expiry": "",
  "updated": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/transferwise-quote');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'amount_fee' => [
    'currency' => '',
    'value' => ''
  ],
  'amount_source' => [
    
  ],
  'amount_target' => [
    
  ],
  'created' => '',
  'currency_source' => '',
  'currency_target' => '',
  'id' => 0,
  'quote_id' => '',
  'rate' => '',
  'time_delivery_estimate' => '',
  'time_expiry' => '',
  'updated' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'amount_fee' => [
    'currency' => '',
    'value' => ''
  ],
  'amount_source' => [
    
  ],
  'amount_target' => [
    
  ],
  'created' => '',
  'currency_source' => '',
  'currency_target' => '',
  'id' => 0,
  'quote_id' => '',
  'rate' => '',
  'time_delivery_estimate' => '',
  'time_expiry' => '',
  'updated' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/transferwise-quote');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/transferwise-quote' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "amount_fee": {
    "currency": "",
    "value": ""
  },
  "amount_source": {},
  "amount_target": {},
  "created": "",
  "currency_source": "",
  "currency_target": "",
  "id": 0,
  "quote_id": "",
  "rate": "",
  "time_delivery_estimate": "",
  "time_expiry": "",
  "updated": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/transferwise-quote' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "amount_fee": {
    "currency": "",
    "value": ""
  },
  "amount_source": {},
  "amount_target": {},
  "created": "",
  "currency_source": "",
  "currency_target": "",
  "id": 0,
  "quote_id": "",
  "rate": "",
  "time_delivery_estimate": "",
  "time_expiry": "",
  "updated": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"amount_fee\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_source\": {},\n  \"amount_target\": {},\n  \"created\": \"\",\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"id\": 0,\n  \"quote_id\": \"\",\n  \"rate\": \"\",\n  \"time_delivery_estimate\": \"\",\n  \"time_expiry\": \"\",\n  \"updated\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/transferwise-quote", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/transferwise-quote"

payload = {
    "amount_fee": {
        "currency": "",
        "value": ""
    },
    "amount_source": {},
    "amount_target": {},
    "created": "",
    "currency_source": "",
    "currency_target": "",
    "id": 0,
    "quote_id": "",
    "rate": "",
    "time_delivery_estimate": "",
    "time_expiry": "",
    "updated": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/transferwise-quote"

payload <- "{\n  \"amount_fee\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_source\": {},\n  \"amount_target\": {},\n  \"created\": \"\",\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"id\": 0,\n  \"quote_id\": \"\",\n  \"rate\": \"\",\n  \"time_delivery_estimate\": \"\",\n  \"time_expiry\": \"\",\n  \"updated\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/transferwise-quote")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"amount_fee\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_source\": {},\n  \"amount_target\": {},\n  \"created\": \"\",\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"id\": 0,\n  \"quote_id\": \"\",\n  \"rate\": \"\",\n  \"time_delivery_estimate\": \"\",\n  \"time_expiry\": \"\",\n  \"updated\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/transferwise-quote') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"amount_fee\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_source\": {},\n  \"amount_target\": {},\n  \"created\": \"\",\n  \"currency_source\": \"\",\n  \"currency_target\": \"\",\n  \"id\": 0,\n  \"quote_id\": \"\",\n  \"rate\": \"\",\n  \"time_delivery_estimate\": \"\",\n  \"time_expiry\": \"\",\n  \"updated\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/transferwise-quote";

    let payload = json!({
        "amount_fee": json!({
            "currency": "",
            "value": ""
        }),
        "amount_source": json!({}),
        "amount_target": json!({}),
        "created": "",
        "currency_source": "",
        "currency_target": "",
        "id": 0,
        "quote_id": "",
        "rate": "",
        "time_delivery_estimate": "",
        "time_expiry": "",
        "updated": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/transferwise-quote \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "amount_fee": {
    "currency": "",
    "value": ""
  },
  "amount_source": {},
  "amount_target": {},
  "created": "",
  "currency_source": "",
  "currency_target": "",
  "id": 0,
  "quote_id": "",
  "rate": "",
  "time_delivery_estimate": "",
  "time_expiry": "",
  "updated": ""
}'
echo '{
  "amount_fee": {
    "currency": "",
    "value": ""
  },
  "amount_source": {},
  "amount_target": {},
  "created": "",
  "currency_source": "",
  "currency_target": "",
  "id": 0,
  "quote_id": "",
  "rate": "",
  "time_delivery_estimate": "",
  "time_expiry": "",
  "updated": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/transferwise-quote \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "amount_fee": {\n    "currency": "",\n    "value": ""\n  },\n  "amount_source": {},\n  "amount_target": {},\n  "created": "",\n  "currency_source": "",\n  "currency_target": "",\n  "id": 0,\n  "quote_id": "",\n  "rate": "",\n  "time_delivery_estimate": "",\n  "time_expiry": "",\n  "updated": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/transferwise-quote
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "amount_fee": [
    "currency": "",
    "value": ""
  ],
  "amount_source": [],
  "amount_target": [],
  "created": "",
  "currency_source": "",
  "currency_target": "",
  "id": 0,
  "quote_id": "",
  "rate": "",
  "time_delivery_estimate": "",
  "time_expiry": "",
  "updated": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/transferwise-quote")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_TransferwiseQuote_for_User
{{baseUrl}}/user/:userID/transferwise-quote/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/transferwise-quote/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/transferwise-quote/:itemId" {:headers {:user-agent ""
                                                                                             :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/transferwise-quote/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/transferwise-quote/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/transferwise-quote/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/transferwise-quote/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/transferwise-quote/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/transferwise-quote/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/transferwise-quote/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/transferwise-quote/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/transferwise-quote/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/transferwise-quote/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/transferwise-quote/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/transferwise-quote/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/transferwise-quote/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/transferwise-quote/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/transferwise-quote/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/transferwise-quote/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/transferwise-quote/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/transferwise-quote/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/transferwise-quote/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/transferwise-quote/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/transferwise-quote/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/transferwise-quote/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/transferwise-quote/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/transferwise-quote/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/transferwise-quote/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/transferwise-quote/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/transferwise-quote/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/transferwise-quote/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/transferwise-quote/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/transferwise-quote/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/transferwise-quote/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/transferwise-quote/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/transferwise-quote/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_TransferwiseQuoteTemporary_for_User
{{baseUrl}}/user/:userID/transferwise-quote-temporary
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
BODY json

{
  "amount_source": {
    "currency": "",
    "value": ""
  },
  "amount_target": {},
  "currency_source": "",
  "currency_target": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/transferwise-quote-temporary");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"amount_source\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_target\": {},\n  \"currency_source\": \"\",\n  \"currency_target\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/transferwise-quote-temporary" {:headers {:user-agent ""
                                                                                                :x-bunq-client-authentication ""}
                                                                                      :content-type :json
                                                                                      :form-params {:amount_source {:currency ""
                                                                                                                    :value ""}
                                                                                                    :amount_target {}
                                                                                                    :currency_source ""
                                                                                                    :currency_target ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/transferwise-quote-temporary"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"amount_source\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_target\": {},\n  \"currency_source\": \"\",\n  \"currency_target\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/transferwise-quote-temporary"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"amount_source\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_target\": {},\n  \"currency_source\": \"\",\n  \"currency_target\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/transferwise-quote-temporary");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"amount_source\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_target\": {},\n  \"currency_source\": \"\",\n  \"currency_target\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/transferwise-quote-temporary"

	payload := strings.NewReader("{\n  \"amount_source\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_target\": {},\n  \"currency_source\": \"\",\n  \"currency_target\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/transferwise-quote-temporary HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 137

{
  "amount_source": {
    "currency": "",
    "value": ""
  },
  "amount_target": {},
  "currency_source": "",
  "currency_target": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/transferwise-quote-temporary")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"amount_source\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_target\": {},\n  \"currency_source\": \"\",\n  \"currency_target\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/transferwise-quote-temporary"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"amount_source\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_target\": {},\n  \"currency_source\": \"\",\n  \"currency_target\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"amount_source\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_target\": {},\n  \"currency_source\": \"\",\n  \"currency_target\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/transferwise-quote-temporary")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/transferwise-quote-temporary")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"amount_source\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_target\": {},\n  \"currency_source\": \"\",\n  \"currency_target\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  amount_source: {
    currency: '',
    value: ''
  },
  amount_target: {},
  currency_source: '',
  currency_target: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/transferwise-quote-temporary');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/transferwise-quote-temporary',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    amount_source: {currency: '', value: ''},
    amount_target: {},
    currency_source: '',
    currency_target: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/transferwise-quote-temporary';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"amount_source":{"currency":"","value":""},"amount_target":{},"currency_source":"","currency_target":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/transferwise-quote-temporary',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "amount_source": {\n    "currency": "",\n    "value": ""\n  },\n  "amount_target": {},\n  "currency_source": "",\n  "currency_target": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"amount_source\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_target\": {},\n  \"currency_source\": \"\",\n  \"currency_target\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/transferwise-quote-temporary")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/transferwise-quote-temporary',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  amount_source: {currency: '', value: ''},
  amount_target: {},
  currency_source: '',
  currency_target: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/transferwise-quote-temporary',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    amount_source: {currency: '', value: ''},
    amount_target: {},
    currency_source: '',
    currency_target: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/transferwise-quote-temporary');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  amount_source: {
    currency: '',
    value: ''
  },
  amount_target: {},
  currency_source: '',
  currency_target: ''
});

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}}/user/:userID/transferwise-quote-temporary',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    amount_source: {currency: '', value: ''},
    amount_target: {},
    currency_source: '',
    currency_target: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/transferwise-quote-temporary';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"amount_source":{"currency":"","value":""},"amount_target":{},"currency_source":"","currency_target":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"amount_source": @{ @"currency": @"", @"value": @"" },
                              @"amount_target": @{  },
                              @"currency_source": @"",
                              @"currency_target": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/transferwise-quote-temporary"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/transferwise-quote-temporary" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"amount_source\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_target\": {},\n  \"currency_source\": \"\",\n  \"currency_target\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/transferwise-quote-temporary",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'amount_source' => [
        'currency' => '',
        'value' => ''
    ],
    'amount_target' => [
        
    ],
    'currency_source' => '',
    'currency_target' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/transferwise-quote-temporary', [
  'body' => '{
  "amount_source": {
    "currency": "",
    "value": ""
  },
  "amount_target": {},
  "currency_source": "",
  "currency_target": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/transferwise-quote-temporary');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'amount_source' => [
    'currency' => '',
    'value' => ''
  ],
  'amount_target' => [
    
  ],
  'currency_source' => '',
  'currency_target' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'amount_source' => [
    'currency' => '',
    'value' => ''
  ],
  'amount_target' => [
    
  ],
  'currency_source' => '',
  'currency_target' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/transferwise-quote-temporary');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/transferwise-quote-temporary' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "amount_source": {
    "currency": "",
    "value": ""
  },
  "amount_target": {},
  "currency_source": "",
  "currency_target": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/transferwise-quote-temporary' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "amount_source": {
    "currency": "",
    "value": ""
  },
  "amount_target": {},
  "currency_source": "",
  "currency_target": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"amount_source\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_target\": {},\n  \"currency_source\": \"\",\n  \"currency_target\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/transferwise-quote-temporary", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/transferwise-quote-temporary"

payload = {
    "amount_source": {
        "currency": "",
        "value": ""
    },
    "amount_target": {},
    "currency_source": "",
    "currency_target": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/transferwise-quote-temporary"

payload <- "{\n  \"amount_source\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_target\": {},\n  \"currency_source\": \"\",\n  \"currency_target\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/transferwise-quote-temporary")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"amount_source\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_target\": {},\n  \"currency_source\": \"\",\n  \"currency_target\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/transferwise-quote-temporary') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"amount_source\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_target\": {},\n  \"currency_source\": \"\",\n  \"currency_target\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/transferwise-quote-temporary";

    let payload = json!({
        "amount_source": json!({
            "currency": "",
            "value": ""
        }),
        "amount_target": json!({}),
        "currency_source": "",
        "currency_target": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/transferwise-quote-temporary \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "amount_source": {
    "currency": "",
    "value": ""
  },
  "amount_target": {},
  "currency_source": "",
  "currency_target": ""
}'
echo '{
  "amount_source": {
    "currency": "",
    "value": ""
  },
  "amount_target": {},
  "currency_source": "",
  "currency_target": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/transferwise-quote-temporary \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "amount_source": {\n    "currency": "",\n    "value": ""\n  },\n  "amount_target": {},\n  "currency_source": "",\n  "currency_target": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/transferwise-quote-temporary
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "amount_source": [
    "currency": "",
    "value": ""
  ],
  "amount_target": [],
  "currency_source": "",
  "currency_target": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/transferwise-quote-temporary")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_TransferwiseQuoteTemporary_for_User
{{baseUrl}}/user/:userID/transferwise-quote-temporary/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/transferwise-quote-temporary/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/transferwise-quote-temporary/:itemId" {:headers {:user-agent ""
                                                                                                       :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/transferwise-quote-temporary/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/transferwise-quote-temporary/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/transferwise-quote-temporary/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/transferwise-quote-temporary/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/transferwise-quote-temporary/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/transferwise-quote-temporary/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/transferwise-quote-temporary/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/transferwise-quote-temporary/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/transferwise-quote-temporary/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/transferwise-quote-temporary/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/transferwise-quote-temporary/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/transferwise-quote-temporary/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/transferwise-quote-temporary/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/transferwise-quote-temporary/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/transferwise-quote-temporary/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/transferwise-quote-temporary/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/transferwise-quote-temporary/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/transferwise-quote-temporary/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/transferwise-quote-temporary/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/transferwise-quote-temporary/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/transferwise-quote-temporary/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/transferwise-quote-temporary/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/transferwise-quote-temporary/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/transferwise-quote-temporary/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/transferwise-quote-temporary/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/transferwise-quote-temporary/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/transferwise-quote-temporary/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/transferwise-quote-temporary/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/transferwise-quote-temporary/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/transferwise-quote-temporary/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/transferwise-quote-temporary/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/transferwise-quote-temporary/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/transferwise-quote-temporary/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/transferwise-quote-temporary/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/transferwise-quote-temporary/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/transferwise-quote-temporary/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/transferwise-quote-temporary/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_TransferwiseRecipient_for_User_TransferwiseQuote
{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
transferwise-quoteID
BODY json

{
  "country": "",
  "detail": [
    {
      "group": {
        "display_format": "",
        "example": "",
        "key": "",
        "max_length": "",
        "min_length": "",
        "name": "",
        "refresh_requirements_on_change": false,
        "required": false,
        "type": "",
        "validation_async": {
          "params": {
            "key": "",
            "parameter_name": "",
            "required": false
          },
          "url": ""
        },
        "validation_regexp": "",
        "values_allowed": {
          "key": "",
          "name": ""
        }
      },
      "key": "",
      "name": "",
      "value": ""
    }
  ],
  "name_account_holder": "",
  "type": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"country\": \"\",\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"name_account_holder\": \"\",\n  \"type\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient" {:headers {:user-agent ""
                                                                                                                                   :x-bunq-client-authentication ""}
                                                                                                                         :content-type :json
                                                                                                                         :form-params {:country ""
                                                                                                                                       :detail [{:group {:display_format ""
                                                                                                                                                         :example ""
                                                                                                                                                         :key ""
                                                                                                                                                         :max_length ""
                                                                                                                                                         :min_length ""
                                                                                                                                                         :name ""
                                                                                                                                                         :refresh_requirements_on_change false
                                                                                                                                                         :required false
                                                                                                                                                         :type ""
                                                                                                                                                         :validation_async {:params {:key ""
                                                                                                                                                                                     :parameter_name ""
                                                                                                                                                                                     :required false}
                                                                                                                                                                            :url ""}
                                                                                                                                                         :validation_regexp ""
                                                                                                                                                         :values_allowed {:key ""
                                                                                                                                                                          :name ""}}
                                                                                                                                                 :key ""
                                                                                                                                                 :name ""
                                                                                                                                                 :value ""}]
                                                                                                                                       :name_account_holder ""
                                                                                                                                       :type ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"country\": \"\",\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"name_account_holder\": \"\",\n  \"type\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"country\": \"\",\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"name_account_holder\": \"\",\n  \"type\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"country\": \"\",\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"name_account_holder\": \"\",\n  \"type\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient"

	payload := strings.NewReader("{\n  \"country\": \"\",\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"name_account_holder\": \"\",\n  \"type\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 708

{
  "country": "",
  "detail": [
    {
      "group": {
        "display_format": "",
        "example": "",
        "key": "",
        "max_length": "",
        "min_length": "",
        "name": "",
        "refresh_requirements_on_change": false,
        "required": false,
        "type": "",
        "validation_async": {
          "params": {
            "key": "",
            "parameter_name": "",
            "required": false
          },
          "url": ""
        },
        "validation_regexp": "",
        "values_allowed": {
          "key": "",
          "name": ""
        }
      },
      "key": "",
      "name": "",
      "value": ""
    }
  ],
  "name_account_holder": "",
  "type": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"country\": \"\",\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"name_account_holder\": \"\",\n  \"type\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"country\": \"\",\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"name_account_holder\": \"\",\n  \"type\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"country\": \"\",\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"name_account_holder\": \"\",\n  \"type\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"country\": \"\",\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"name_account_holder\": \"\",\n  \"type\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  country: '',
  detail: [
    {
      group: {
        display_format: '',
        example: '',
        key: '',
        max_length: '',
        min_length: '',
        name: '',
        refresh_requirements_on_change: false,
        required: false,
        type: '',
        validation_async: {
          params: {
            key: '',
            parameter_name: '',
            required: false
          },
          url: ''
        },
        validation_regexp: '',
        values_allowed: {
          key: '',
          name: ''
        }
      },
      key: '',
      name: '',
      value: ''
    }
  ],
  name_account_holder: '',
  type: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    country: '',
    detail: [
      {
        group: {
          display_format: '',
          example: '',
          key: '',
          max_length: '',
          min_length: '',
          name: '',
          refresh_requirements_on_change: false,
          required: false,
          type: '',
          validation_async: {params: {key: '', parameter_name: '', required: false}, url: ''},
          validation_regexp: '',
          values_allowed: {key: '', name: ''}
        },
        key: '',
        name: '',
        value: ''
      }
    ],
    name_account_holder: '',
    type: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"country":"","detail":[{"group":{"display_format":"","example":"","key":"","max_length":"","min_length":"","name":"","refresh_requirements_on_change":false,"required":false,"type":"","validation_async":{"params":{"key":"","parameter_name":"","required":false},"url":""},"validation_regexp":"","values_allowed":{"key":"","name":""}},"key":"","name":"","value":""}],"name_account_holder":"","type":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "country": "",\n  "detail": [\n    {\n      "group": {\n        "display_format": "",\n        "example": "",\n        "key": "",\n        "max_length": "",\n        "min_length": "",\n        "name": "",\n        "refresh_requirements_on_change": false,\n        "required": false,\n        "type": "",\n        "validation_async": {\n          "params": {\n            "key": "",\n            "parameter_name": "",\n            "required": false\n          },\n          "url": ""\n        },\n        "validation_regexp": "",\n        "values_allowed": {\n          "key": "",\n          "name": ""\n        }\n      },\n      "key": "",\n      "name": "",\n      "value": ""\n    }\n  ],\n  "name_account_holder": "",\n  "type": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"country\": \"\",\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"name_account_holder\": \"\",\n  \"type\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  country: '',
  detail: [
    {
      group: {
        display_format: '',
        example: '',
        key: '',
        max_length: '',
        min_length: '',
        name: '',
        refresh_requirements_on_change: false,
        required: false,
        type: '',
        validation_async: {params: {key: '', parameter_name: '', required: false}, url: ''},
        validation_regexp: '',
        values_allowed: {key: '', name: ''}
      },
      key: '',
      name: '',
      value: ''
    }
  ],
  name_account_holder: '',
  type: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    country: '',
    detail: [
      {
        group: {
          display_format: '',
          example: '',
          key: '',
          max_length: '',
          min_length: '',
          name: '',
          refresh_requirements_on_change: false,
          required: false,
          type: '',
          validation_async: {params: {key: '', parameter_name: '', required: false}, url: ''},
          validation_regexp: '',
          values_allowed: {key: '', name: ''}
        },
        key: '',
        name: '',
        value: ''
      }
    ],
    name_account_holder: '',
    type: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  country: '',
  detail: [
    {
      group: {
        display_format: '',
        example: '',
        key: '',
        max_length: '',
        min_length: '',
        name: '',
        refresh_requirements_on_change: false,
        required: false,
        type: '',
        validation_async: {
          params: {
            key: '',
            parameter_name: '',
            required: false
          },
          url: ''
        },
        validation_regexp: '',
        values_allowed: {
          key: '',
          name: ''
        }
      },
      key: '',
      name: '',
      value: ''
    }
  ],
  name_account_holder: '',
  type: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    country: '',
    detail: [
      {
        group: {
          display_format: '',
          example: '',
          key: '',
          max_length: '',
          min_length: '',
          name: '',
          refresh_requirements_on_change: false,
          required: false,
          type: '',
          validation_async: {params: {key: '', parameter_name: '', required: false}, url: ''},
          validation_regexp: '',
          values_allowed: {key: '', name: ''}
        },
        key: '',
        name: '',
        value: ''
      }
    ],
    name_account_holder: '',
    type: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"country":"","detail":[{"group":{"display_format":"","example":"","key":"","max_length":"","min_length":"","name":"","refresh_requirements_on_change":false,"required":false,"type":"","validation_async":{"params":{"key":"","parameter_name":"","required":false},"url":""},"validation_regexp":"","values_allowed":{"key":"","name":""}},"key":"","name":"","value":""}],"name_account_holder":"","type":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"country": @"",
                              @"detail": @[ @{ @"group": @{ @"display_format": @"", @"example": @"", @"key": @"", @"max_length": @"", @"min_length": @"", @"name": @"", @"refresh_requirements_on_change": @NO, @"required": @NO, @"type": @"", @"validation_async": @{ @"params": @{ @"key": @"", @"parameter_name": @"", @"required": @NO }, @"url": @"" }, @"validation_regexp": @"", @"values_allowed": @{ @"key": @"", @"name": @"" } }, @"key": @"", @"name": @"", @"value": @"" } ],
                              @"name_account_holder": @"",
                              @"type": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"country\": \"\",\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"name_account_holder\": \"\",\n  \"type\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'country' => '',
    'detail' => [
        [
                'group' => [
                                'display_format' => '',
                                'example' => '',
                                'key' => '',
                                'max_length' => '',
                                'min_length' => '',
                                'name' => '',
                                'refresh_requirements_on_change' => null,
                                'required' => null,
                                'type' => '',
                                'validation_async' => [
                                                                'params' => [
                                                                                                                                'key' => '',
                                                                                                                                'parameter_name' => '',
                                                                                                                                'required' => null
                                                                ],
                                                                'url' => ''
                                ],
                                'validation_regexp' => '',
                                'values_allowed' => [
                                                                'key' => '',
                                                                'name' => ''
                                ]
                ],
                'key' => '',
                'name' => '',
                'value' => ''
        ]
    ],
    'name_account_holder' => '',
    'type' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient', [
  'body' => '{
  "country": "",
  "detail": [
    {
      "group": {
        "display_format": "",
        "example": "",
        "key": "",
        "max_length": "",
        "min_length": "",
        "name": "",
        "refresh_requirements_on_change": false,
        "required": false,
        "type": "",
        "validation_async": {
          "params": {
            "key": "",
            "parameter_name": "",
            "required": false
          },
          "url": ""
        },
        "validation_regexp": "",
        "values_allowed": {
          "key": "",
          "name": ""
        }
      },
      "key": "",
      "name": "",
      "value": ""
    }
  ],
  "name_account_holder": "",
  "type": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'country' => '',
  'detail' => [
    [
        'group' => [
                'display_format' => '',
                'example' => '',
                'key' => '',
                'max_length' => '',
                'min_length' => '',
                'name' => '',
                'refresh_requirements_on_change' => null,
                'required' => null,
                'type' => '',
                'validation_async' => [
                                'params' => [
                                                                'key' => '',
                                                                'parameter_name' => '',
                                                                'required' => null
                                ],
                                'url' => ''
                ],
                'validation_regexp' => '',
                'values_allowed' => [
                                'key' => '',
                                'name' => ''
                ]
        ],
        'key' => '',
        'name' => '',
        'value' => ''
    ]
  ],
  'name_account_holder' => '',
  'type' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'country' => '',
  'detail' => [
    [
        'group' => [
                'display_format' => '',
                'example' => '',
                'key' => '',
                'max_length' => '',
                'min_length' => '',
                'name' => '',
                'refresh_requirements_on_change' => null,
                'required' => null,
                'type' => '',
                'validation_async' => [
                                'params' => [
                                                                'key' => '',
                                                                'parameter_name' => '',
                                                                'required' => null
                                ],
                                'url' => ''
                ],
                'validation_regexp' => '',
                'values_allowed' => [
                                'key' => '',
                                'name' => ''
                ]
        ],
        'key' => '',
        'name' => '',
        'value' => ''
    ]
  ],
  'name_account_holder' => '',
  'type' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "country": "",
  "detail": [
    {
      "group": {
        "display_format": "",
        "example": "",
        "key": "",
        "max_length": "",
        "min_length": "",
        "name": "",
        "refresh_requirements_on_change": false,
        "required": false,
        "type": "",
        "validation_async": {
          "params": {
            "key": "",
            "parameter_name": "",
            "required": false
          },
          "url": ""
        },
        "validation_regexp": "",
        "values_allowed": {
          "key": "",
          "name": ""
        }
      },
      "key": "",
      "name": "",
      "value": ""
    }
  ],
  "name_account_holder": "",
  "type": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "country": "",
  "detail": [
    {
      "group": {
        "display_format": "",
        "example": "",
        "key": "",
        "max_length": "",
        "min_length": "",
        "name": "",
        "refresh_requirements_on_change": false,
        "required": false,
        "type": "",
        "validation_async": {
          "params": {
            "key": "",
            "parameter_name": "",
            "required": false
          },
          "url": ""
        },
        "validation_regexp": "",
        "values_allowed": {
          "key": "",
          "name": ""
        }
      },
      "key": "",
      "name": "",
      "value": ""
    }
  ],
  "name_account_holder": "",
  "type": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"country\": \"\",\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"name_account_holder\": \"\",\n  \"type\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient"

payload = {
    "country": "",
    "detail": [
        {
            "group": {
                "display_format": "",
                "example": "",
                "key": "",
                "max_length": "",
                "min_length": "",
                "name": "",
                "refresh_requirements_on_change": False,
                "required": False,
                "type": "",
                "validation_async": {
                    "params": {
                        "key": "",
                        "parameter_name": "",
                        "required": False
                    },
                    "url": ""
                },
                "validation_regexp": "",
                "values_allowed": {
                    "key": "",
                    "name": ""
                }
            },
            "key": "",
            "name": "",
            "value": ""
        }
    ],
    "name_account_holder": "",
    "type": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient"

payload <- "{\n  \"country\": \"\",\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"name_account_holder\": \"\",\n  \"type\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"country\": \"\",\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"name_account_holder\": \"\",\n  \"type\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"country\": \"\",\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"name_account_holder\": \"\",\n  \"type\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient";

    let payload = json!({
        "country": "",
        "detail": (
            json!({
                "group": json!({
                    "display_format": "",
                    "example": "",
                    "key": "",
                    "max_length": "",
                    "min_length": "",
                    "name": "",
                    "refresh_requirements_on_change": false,
                    "required": false,
                    "type": "",
                    "validation_async": json!({
                        "params": json!({
                            "key": "",
                            "parameter_name": "",
                            "required": false
                        }),
                        "url": ""
                    }),
                    "validation_regexp": "",
                    "values_allowed": json!({
                        "key": "",
                        "name": ""
                    })
                }),
                "key": "",
                "name": "",
                "value": ""
            })
        ),
        "name_account_holder": "",
        "type": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "country": "",
  "detail": [
    {
      "group": {
        "display_format": "",
        "example": "",
        "key": "",
        "max_length": "",
        "min_length": "",
        "name": "",
        "refresh_requirements_on_change": false,
        "required": false,
        "type": "",
        "validation_async": {
          "params": {
            "key": "",
            "parameter_name": "",
            "required": false
          },
          "url": ""
        },
        "validation_regexp": "",
        "values_allowed": {
          "key": "",
          "name": ""
        }
      },
      "key": "",
      "name": "",
      "value": ""
    }
  ],
  "name_account_holder": "",
  "type": ""
}'
echo '{
  "country": "",
  "detail": [
    {
      "group": {
        "display_format": "",
        "example": "",
        "key": "",
        "max_length": "",
        "min_length": "",
        "name": "",
        "refresh_requirements_on_change": false,
        "required": false,
        "type": "",
        "validation_async": {
          "params": {
            "key": "",
            "parameter_name": "",
            "required": false
          },
          "url": ""
        },
        "validation_regexp": "",
        "values_allowed": {
          "key": "",
          "name": ""
        }
      },
      "key": "",
      "name": "",
      "value": ""
    }
  ],
  "name_account_holder": "",
  "type": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "country": "",\n  "detail": [\n    {\n      "group": {\n        "display_format": "",\n        "example": "",\n        "key": "",\n        "max_length": "",\n        "min_length": "",\n        "name": "",\n        "refresh_requirements_on_change": false,\n        "required": false,\n        "type": "",\n        "validation_async": {\n          "params": {\n            "key": "",\n            "parameter_name": "",\n            "required": false\n          },\n          "url": ""\n        },\n        "validation_regexp": "",\n        "values_allowed": {\n          "key": "",\n          "name": ""\n        }\n      },\n      "key": "",\n      "name": "",\n      "value": ""\n    }\n  ],\n  "name_account_holder": "",\n  "type": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "country": "",
  "detail": [
    [
      "group": [
        "display_format": "",
        "example": "",
        "key": "",
        "max_length": "",
        "min_length": "",
        "name": "",
        "refresh_requirements_on_change": false,
        "required": false,
        "type": "",
        "validation_async": [
          "params": [
            "key": "",
            "parameter_name": "",
            "required": false
          ],
          "url": ""
        ],
        "validation_regexp": "",
        "values_allowed": [
          "key": "",
          "name": ""
        ]
      ],
      "key": "",
      "name": "",
      "value": ""
    ]
  ],
  "name_account_holder": "",
  "type": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_TransferwiseRecipient_for_User_TransferwiseQuote
{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
transferwise-quoteID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId" {:headers {:user-agent ""
                                                                                                                                             :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId"]
                                                       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}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_TransferwiseRecipient_for_User_TransferwiseQuote
{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
transferwise-quoteID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient" {:headers {:user-agent ""
                                                                                                                                  :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_TransferwiseRecipient_for_User_TransferwiseQuote
{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
transferwise-quoteID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId" {:headers {:user-agent ""
                                                                                                                                          :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_TransferwiseRecipientRequirement_for_User_TransferwiseQuote
{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
transferwise-quoteID
BODY json

{
  "country": "",
  "detail": [
    {
      "group": {
        "display_format": "",
        "example": "",
        "key": "",
        "max_length": "",
        "min_length": "",
        "name": "",
        "refresh_requirements_on_change": false,
        "required": false,
        "type": "",
        "validation_async": {
          "params": {
            "key": "",
            "parameter_name": "",
            "required": false
          },
          "url": ""
        },
        "validation_regexp": "",
        "values_allowed": {
          "key": "",
          "name": ""
        }
      },
      "key": "",
      "name": "",
      "value": ""
    }
  ],
  "name_account_holder": "",
  "type": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"country\": \"\",\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"name_account_holder\": \"\",\n  \"type\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement" {:headers {:user-agent ""
                                                                                                                                               :x-bunq-client-authentication ""}
                                                                                                                                     :content-type :json
                                                                                                                                     :form-params {:country ""
                                                                                                                                                   :detail [{:group {:display_format ""
                                                                                                                                                                     :example ""
                                                                                                                                                                     :key ""
                                                                                                                                                                     :max_length ""
                                                                                                                                                                     :min_length ""
                                                                                                                                                                     :name ""
                                                                                                                                                                     :refresh_requirements_on_change false
                                                                                                                                                                     :required false
                                                                                                                                                                     :type ""
                                                                                                                                                                     :validation_async {:params {:key ""
                                                                                                                                                                                                 :parameter_name ""
                                                                                                                                                                                                 :required false}
                                                                                                                                                                                        :url ""}
                                                                                                                                                                     :validation_regexp ""
                                                                                                                                                                     :values_allowed {:key ""
                                                                                                                                                                                      :name ""}}
                                                                                                                                                             :key ""
                                                                                                                                                             :name ""
                                                                                                                                                             :value ""}]
                                                                                                                                                   :name_account_holder ""
                                                                                                                                                   :type ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"country\": \"\",\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"name_account_holder\": \"\",\n  \"type\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"country\": \"\",\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"name_account_holder\": \"\",\n  \"type\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"country\": \"\",\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"name_account_holder\": \"\",\n  \"type\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement"

	payload := strings.NewReader("{\n  \"country\": \"\",\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"name_account_holder\": \"\",\n  \"type\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 708

{
  "country": "",
  "detail": [
    {
      "group": {
        "display_format": "",
        "example": "",
        "key": "",
        "max_length": "",
        "min_length": "",
        "name": "",
        "refresh_requirements_on_change": false,
        "required": false,
        "type": "",
        "validation_async": {
          "params": {
            "key": "",
            "parameter_name": "",
            "required": false
          },
          "url": ""
        },
        "validation_regexp": "",
        "values_allowed": {
          "key": "",
          "name": ""
        }
      },
      "key": "",
      "name": "",
      "value": ""
    }
  ],
  "name_account_holder": "",
  "type": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"country\": \"\",\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"name_account_holder\": \"\",\n  \"type\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"country\": \"\",\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"name_account_holder\": \"\",\n  \"type\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"country\": \"\",\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"name_account_holder\": \"\",\n  \"type\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"country\": \"\",\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"name_account_holder\": \"\",\n  \"type\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  country: '',
  detail: [
    {
      group: {
        display_format: '',
        example: '',
        key: '',
        max_length: '',
        min_length: '',
        name: '',
        refresh_requirements_on_change: false,
        required: false,
        type: '',
        validation_async: {
          params: {
            key: '',
            parameter_name: '',
            required: false
          },
          url: ''
        },
        validation_regexp: '',
        values_allowed: {
          key: '',
          name: ''
        }
      },
      key: '',
      name: '',
      value: ''
    }
  ],
  name_account_holder: '',
  type: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    country: '',
    detail: [
      {
        group: {
          display_format: '',
          example: '',
          key: '',
          max_length: '',
          min_length: '',
          name: '',
          refresh_requirements_on_change: false,
          required: false,
          type: '',
          validation_async: {params: {key: '', parameter_name: '', required: false}, url: ''},
          validation_regexp: '',
          values_allowed: {key: '', name: ''}
        },
        key: '',
        name: '',
        value: ''
      }
    ],
    name_account_holder: '',
    type: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"country":"","detail":[{"group":{"display_format":"","example":"","key":"","max_length":"","min_length":"","name":"","refresh_requirements_on_change":false,"required":false,"type":"","validation_async":{"params":{"key":"","parameter_name":"","required":false},"url":""},"validation_regexp":"","values_allowed":{"key":"","name":""}},"key":"","name":"","value":""}],"name_account_holder":"","type":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "country": "",\n  "detail": [\n    {\n      "group": {\n        "display_format": "",\n        "example": "",\n        "key": "",\n        "max_length": "",\n        "min_length": "",\n        "name": "",\n        "refresh_requirements_on_change": false,\n        "required": false,\n        "type": "",\n        "validation_async": {\n          "params": {\n            "key": "",\n            "parameter_name": "",\n            "required": false\n          },\n          "url": ""\n        },\n        "validation_regexp": "",\n        "values_allowed": {\n          "key": "",\n          "name": ""\n        }\n      },\n      "key": "",\n      "name": "",\n      "value": ""\n    }\n  ],\n  "name_account_holder": "",\n  "type": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"country\": \"\",\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"name_account_holder\": \"\",\n  \"type\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  country: '',
  detail: [
    {
      group: {
        display_format: '',
        example: '',
        key: '',
        max_length: '',
        min_length: '',
        name: '',
        refresh_requirements_on_change: false,
        required: false,
        type: '',
        validation_async: {params: {key: '', parameter_name: '', required: false}, url: ''},
        validation_regexp: '',
        values_allowed: {key: '', name: ''}
      },
      key: '',
      name: '',
      value: ''
    }
  ],
  name_account_holder: '',
  type: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    country: '',
    detail: [
      {
        group: {
          display_format: '',
          example: '',
          key: '',
          max_length: '',
          min_length: '',
          name: '',
          refresh_requirements_on_change: false,
          required: false,
          type: '',
          validation_async: {params: {key: '', parameter_name: '', required: false}, url: ''},
          validation_regexp: '',
          values_allowed: {key: '', name: ''}
        },
        key: '',
        name: '',
        value: ''
      }
    ],
    name_account_holder: '',
    type: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  country: '',
  detail: [
    {
      group: {
        display_format: '',
        example: '',
        key: '',
        max_length: '',
        min_length: '',
        name: '',
        refresh_requirements_on_change: false,
        required: false,
        type: '',
        validation_async: {
          params: {
            key: '',
            parameter_name: '',
            required: false
          },
          url: ''
        },
        validation_regexp: '',
        values_allowed: {
          key: '',
          name: ''
        }
      },
      key: '',
      name: '',
      value: ''
    }
  ],
  name_account_holder: '',
  type: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    country: '',
    detail: [
      {
        group: {
          display_format: '',
          example: '',
          key: '',
          max_length: '',
          min_length: '',
          name: '',
          refresh_requirements_on_change: false,
          required: false,
          type: '',
          validation_async: {params: {key: '', parameter_name: '', required: false}, url: ''},
          validation_regexp: '',
          values_allowed: {key: '', name: ''}
        },
        key: '',
        name: '',
        value: ''
      }
    ],
    name_account_holder: '',
    type: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"country":"","detail":[{"group":{"display_format":"","example":"","key":"","max_length":"","min_length":"","name":"","refresh_requirements_on_change":false,"required":false,"type":"","validation_async":{"params":{"key":"","parameter_name":"","required":false},"url":""},"validation_regexp":"","values_allowed":{"key":"","name":""}},"key":"","name":"","value":""}],"name_account_holder":"","type":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"country": @"",
                              @"detail": @[ @{ @"group": @{ @"display_format": @"", @"example": @"", @"key": @"", @"max_length": @"", @"min_length": @"", @"name": @"", @"refresh_requirements_on_change": @NO, @"required": @NO, @"type": @"", @"validation_async": @{ @"params": @{ @"key": @"", @"parameter_name": @"", @"required": @NO }, @"url": @"" }, @"validation_regexp": @"", @"values_allowed": @{ @"key": @"", @"name": @"" } }, @"key": @"", @"name": @"", @"value": @"" } ],
                              @"name_account_holder": @"",
                              @"type": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"country\": \"\",\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"name_account_holder\": \"\",\n  \"type\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'country' => '',
    'detail' => [
        [
                'group' => [
                                'display_format' => '',
                                'example' => '',
                                'key' => '',
                                'max_length' => '',
                                'min_length' => '',
                                'name' => '',
                                'refresh_requirements_on_change' => null,
                                'required' => null,
                                'type' => '',
                                'validation_async' => [
                                                                'params' => [
                                                                                                                                'key' => '',
                                                                                                                                'parameter_name' => '',
                                                                                                                                'required' => null
                                                                ],
                                                                'url' => ''
                                ],
                                'validation_regexp' => '',
                                'values_allowed' => [
                                                                'key' => '',
                                                                'name' => ''
                                ]
                ],
                'key' => '',
                'name' => '',
                'value' => ''
        ]
    ],
    'name_account_holder' => '',
    'type' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement', [
  'body' => '{
  "country": "",
  "detail": [
    {
      "group": {
        "display_format": "",
        "example": "",
        "key": "",
        "max_length": "",
        "min_length": "",
        "name": "",
        "refresh_requirements_on_change": false,
        "required": false,
        "type": "",
        "validation_async": {
          "params": {
            "key": "",
            "parameter_name": "",
            "required": false
          },
          "url": ""
        },
        "validation_regexp": "",
        "values_allowed": {
          "key": "",
          "name": ""
        }
      },
      "key": "",
      "name": "",
      "value": ""
    }
  ],
  "name_account_holder": "",
  "type": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'country' => '',
  'detail' => [
    [
        'group' => [
                'display_format' => '',
                'example' => '',
                'key' => '',
                'max_length' => '',
                'min_length' => '',
                'name' => '',
                'refresh_requirements_on_change' => null,
                'required' => null,
                'type' => '',
                'validation_async' => [
                                'params' => [
                                                                'key' => '',
                                                                'parameter_name' => '',
                                                                'required' => null
                                ],
                                'url' => ''
                ],
                'validation_regexp' => '',
                'values_allowed' => [
                                'key' => '',
                                'name' => ''
                ]
        ],
        'key' => '',
        'name' => '',
        'value' => ''
    ]
  ],
  'name_account_holder' => '',
  'type' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'country' => '',
  'detail' => [
    [
        'group' => [
                'display_format' => '',
                'example' => '',
                'key' => '',
                'max_length' => '',
                'min_length' => '',
                'name' => '',
                'refresh_requirements_on_change' => null,
                'required' => null,
                'type' => '',
                'validation_async' => [
                                'params' => [
                                                                'key' => '',
                                                                'parameter_name' => '',
                                                                'required' => null
                                ],
                                'url' => ''
                ],
                'validation_regexp' => '',
                'values_allowed' => [
                                'key' => '',
                                'name' => ''
                ]
        ],
        'key' => '',
        'name' => '',
        'value' => ''
    ]
  ],
  'name_account_holder' => '',
  'type' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "country": "",
  "detail": [
    {
      "group": {
        "display_format": "",
        "example": "",
        "key": "",
        "max_length": "",
        "min_length": "",
        "name": "",
        "refresh_requirements_on_change": false,
        "required": false,
        "type": "",
        "validation_async": {
          "params": {
            "key": "",
            "parameter_name": "",
            "required": false
          },
          "url": ""
        },
        "validation_regexp": "",
        "values_allowed": {
          "key": "",
          "name": ""
        }
      },
      "key": "",
      "name": "",
      "value": ""
    }
  ],
  "name_account_holder": "",
  "type": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "country": "",
  "detail": [
    {
      "group": {
        "display_format": "",
        "example": "",
        "key": "",
        "max_length": "",
        "min_length": "",
        "name": "",
        "refresh_requirements_on_change": false,
        "required": false,
        "type": "",
        "validation_async": {
          "params": {
            "key": "",
            "parameter_name": "",
            "required": false
          },
          "url": ""
        },
        "validation_regexp": "",
        "values_allowed": {
          "key": "",
          "name": ""
        }
      },
      "key": "",
      "name": "",
      "value": ""
    }
  ],
  "name_account_holder": "",
  "type": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"country\": \"\",\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"name_account_holder\": \"\",\n  \"type\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement"

payload = {
    "country": "",
    "detail": [
        {
            "group": {
                "display_format": "",
                "example": "",
                "key": "",
                "max_length": "",
                "min_length": "",
                "name": "",
                "refresh_requirements_on_change": False,
                "required": False,
                "type": "",
                "validation_async": {
                    "params": {
                        "key": "",
                        "parameter_name": "",
                        "required": False
                    },
                    "url": ""
                },
                "validation_regexp": "",
                "values_allowed": {
                    "key": "",
                    "name": ""
                }
            },
            "key": "",
            "name": "",
            "value": ""
        }
    ],
    "name_account_holder": "",
    "type": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement"

payload <- "{\n  \"country\": \"\",\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"name_account_holder\": \"\",\n  \"type\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"country\": \"\",\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"name_account_holder\": \"\",\n  \"type\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"country\": \"\",\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"name_account_holder\": \"\",\n  \"type\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement";

    let payload = json!({
        "country": "",
        "detail": (
            json!({
                "group": json!({
                    "display_format": "",
                    "example": "",
                    "key": "",
                    "max_length": "",
                    "min_length": "",
                    "name": "",
                    "refresh_requirements_on_change": false,
                    "required": false,
                    "type": "",
                    "validation_async": json!({
                        "params": json!({
                            "key": "",
                            "parameter_name": "",
                            "required": false
                        }),
                        "url": ""
                    }),
                    "validation_regexp": "",
                    "values_allowed": json!({
                        "key": "",
                        "name": ""
                    })
                }),
                "key": "",
                "name": "",
                "value": ""
            })
        ),
        "name_account_holder": "",
        "type": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "country": "",
  "detail": [
    {
      "group": {
        "display_format": "",
        "example": "",
        "key": "",
        "max_length": "",
        "min_length": "",
        "name": "",
        "refresh_requirements_on_change": false,
        "required": false,
        "type": "",
        "validation_async": {
          "params": {
            "key": "",
            "parameter_name": "",
            "required": false
          },
          "url": ""
        },
        "validation_regexp": "",
        "values_allowed": {
          "key": "",
          "name": ""
        }
      },
      "key": "",
      "name": "",
      "value": ""
    }
  ],
  "name_account_holder": "",
  "type": ""
}'
echo '{
  "country": "",
  "detail": [
    {
      "group": {
        "display_format": "",
        "example": "",
        "key": "",
        "max_length": "",
        "min_length": "",
        "name": "",
        "refresh_requirements_on_change": false,
        "required": false,
        "type": "",
        "validation_async": {
          "params": {
            "key": "",
            "parameter_name": "",
            "required": false
          },
          "url": ""
        },
        "validation_regexp": "",
        "values_allowed": {
          "key": "",
          "name": ""
        }
      },
      "key": "",
      "name": "",
      "value": ""
    }
  ],
  "name_account_holder": "",
  "type": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "country": "",\n  "detail": [\n    {\n      "group": {\n        "display_format": "",\n        "example": "",\n        "key": "",\n        "max_length": "",\n        "min_length": "",\n        "name": "",\n        "refresh_requirements_on_change": false,\n        "required": false,\n        "type": "",\n        "validation_async": {\n          "params": {\n            "key": "",\n            "parameter_name": "",\n            "required": false\n          },\n          "url": ""\n        },\n        "validation_regexp": "",\n        "values_allowed": {\n          "key": "",\n          "name": ""\n        }\n      },\n      "key": "",\n      "name": "",\n      "value": ""\n    }\n  ],\n  "name_account_holder": "",\n  "type": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "country": "",
  "detail": [
    [
      "group": [
        "display_format": "",
        "example": "",
        "key": "",
        "max_length": "",
        "min_length": "",
        "name": "",
        "refresh_requirements_on_change": false,
        "required": false,
        "type": "",
        "validation_async": [
          "params": [
            "key": "",
            "parameter_name": "",
            "required": false
          ],
          "url": ""
        ],
        "validation_regexp": "",
        "values_allowed": [
          "key": "",
          "name": ""
        ]
      ],
      "key": "",
      "name": "",
      "value": ""
    ]
  ],
  "name_account_holder": "",
  "type": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_TransferwiseRecipientRequirement_for_User_TransferwiseQuote
{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
transferwise-quoteID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement" {:headers {:user-agent ""
                                                                                                                                              :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-recipient-requirement")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_TransferwiseTransfer_for_User_TransferwiseQuote
{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
transferwise-quoteID
BODY json

{
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "amount_source": {
    "currency": "",
    "value": ""
  },
  "amount_target": {},
  "counterparty_alias": {},
  "monetary_account_id": "",
  "pay_in_reference": "",
  "quote": {
    "amount_fee": {},
    "amount_source": {},
    "amount_target": {},
    "created": "",
    "currency_source": "",
    "currency_target": "",
    "id": 0,
    "quote_id": "",
    "rate": "",
    "time_delivery_estimate": "",
    "time_expiry": "",
    "updated": ""
  },
  "rate": "",
  "recipient_id": "",
  "reference": "",
  "status": "",
  "status_transferwise": "",
  "status_transferwise_issue": "",
  "sub_status": "",
  "time_delivery_estimate": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_source\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_target\": {},\n  \"counterparty_alias\": {},\n  \"monetary_account_id\": \"\",\n  \"pay_in_reference\": \"\",\n  \"quote\": {\n    \"amount_fee\": {},\n    \"amount_source\": {},\n    \"amount_target\": {},\n    \"created\": \"\",\n    \"currency_source\": \"\",\n    \"currency_target\": \"\",\n    \"id\": 0,\n    \"quote_id\": \"\",\n    \"rate\": \"\",\n    \"time_delivery_estimate\": \"\",\n    \"time_expiry\": \"\",\n    \"updated\": \"\"\n  },\n  \"rate\": \"\",\n  \"recipient_id\": \"\",\n  \"reference\": \"\",\n  \"status\": \"\",\n  \"status_transferwise\": \"\",\n  \"status_transferwise_issue\": \"\",\n  \"sub_status\": \"\",\n  \"time_delivery_estimate\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer" {:headers {:user-agent ""
                                                                                                                                  :x-bunq-client-authentication ""}
                                                                                                                        :content-type :json
                                                                                                                        :form-params {:alias {:avatar {:anchor_uuid ""
                                                                                                                                                       :image [{:attachment_public_uuid ""
                                                                                                                                                                :content_type ""
                                                                                                                                                                :height 0
                                                                                                                                                                :width 0}]
                                                                                                                                                       :style ""
                                                                                                                                                       :uuid ""}
                                                                                                                                              :bunq_me {:name ""
                                                                                                                                                        :service ""
                                                                                                                                                        :type ""
                                                                                                                                                        :value ""}
                                                                                                                                              :country ""
                                                                                                                                              :display_name ""
                                                                                                                                              :iban ""
                                                                                                                                              :is_light false
                                                                                                                                              :label_user {:avatar {}
                                                                                                                                                           :country ""
                                                                                                                                                           :display_name ""
                                                                                                                                                           :public_nick_name ""
                                                                                                                                                           :uuid ""}
                                                                                                                                              :merchant_category_code ""
                                                                                                                                              :swift_account_number ""
                                                                                                                                              :swift_bic ""
                                                                                                                                              :transferwise_account_number ""
                                                                                                                                              :transferwise_bank_code ""}
                                                                                                                                      :amount_source {:currency ""
                                                                                                                                                      :value ""}
                                                                                                                                      :amount_target {}
                                                                                                                                      :counterparty_alias {}
                                                                                                                                      :monetary_account_id ""
                                                                                                                                      :pay_in_reference ""
                                                                                                                                      :quote {:amount_fee {}
                                                                                                                                              :amount_source {}
                                                                                                                                              :amount_target {}
                                                                                                                                              :created ""
                                                                                                                                              :currency_source ""
                                                                                                                                              :currency_target ""
                                                                                                                                              :id 0
                                                                                                                                              :quote_id ""
                                                                                                                                              :rate ""
                                                                                                                                              :time_delivery_estimate ""
                                                                                                                                              :time_expiry ""
                                                                                                                                              :updated ""}
                                                                                                                                      :rate ""
                                                                                                                                      :recipient_id ""
                                                                                                                                      :reference ""
                                                                                                                                      :status ""
                                                                                                                                      :status_transferwise ""
                                                                                                                                      :status_transferwise_issue ""
                                                                                                                                      :sub_status ""
                                                                                                                                      :time_delivery_estimate ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_source\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_target\": {},\n  \"counterparty_alias\": {},\n  \"monetary_account_id\": \"\",\n  \"pay_in_reference\": \"\",\n  \"quote\": {\n    \"amount_fee\": {},\n    \"amount_source\": {},\n    \"amount_target\": {},\n    \"created\": \"\",\n    \"currency_source\": \"\",\n    \"currency_target\": \"\",\n    \"id\": 0,\n    \"quote_id\": \"\",\n    \"rate\": \"\",\n    \"time_delivery_estimate\": \"\",\n    \"time_expiry\": \"\",\n    \"updated\": \"\"\n  },\n  \"rate\": \"\",\n  \"recipient_id\": \"\",\n  \"reference\": \"\",\n  \"status\": \"\",\n  \"status_transferwise\": \"\",\n  \"status_transferwise_issue\": \"\",\n  \"sub_status\": \"\",\n  \"time_delivery_estimate\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_source\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_target\": {},\n  \"counterparty_alias\": {},\n  \"monetary_account_id\": \"\",\n  \"pay_in_reference\": \"\",\n  \"quote\": {\n    \"amount_fee\": {},\n    \"amount_source\": {},\n    \"amount_target\": {},\n    \"created\": \"\",\n    \"currency_source\": \"\",\n    \"currency_target\": \"\",\n    \"id\": 0,\n    \"quote_id\": \"\",\n    \"rate\": \"\",\n    \"time_delivery_estimate\": \"\",\n    \"time_expiry\": \"\",\n    \"updated\": \"\"\n  },\n  \"rate\": \"\",\n  \"recipient_id\": \"\",\n  \"reference\": \"\",\n  \"status\": \"\",\n  \"status_transferwise\": \"\",\n  \"status_transferwise_issue\": \"\",\n  \"sub_status\": \"\",\n  \"time_delivery_estimate\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_source\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_target\": {},\n  \"counterparty_alias\": {},\n  \"monetary_account_id\": \"\",\n  \"pay_in_reference\": \"\",\n  \"quote\": {\n    \"amount_fee\": {},\n    \"amount_source\": {},\n    \"amount_target\": {},\n    \"created\": \"\",\n    \"currency_source\": \"\",\n    \"currency_target\": \"\",\n    \"id\": 0,\n    \"quote_id\": \"\",\n    \"rate\": \"\",\n    \"time_delivery_estimate\": \"\",\n    \"time_expiry\": \"\",\n    \"updated\": \"\"\n  },\n  \"rate\": \"\",\n  \"recipient_id\": \"\",\n  \"reference\": \"\",\n  \"status\": \"\",\n  \"status_transferwise\": \"\",\n  \"status_transferwise_issue\": \"\",\n  \"sub_status\": \"\",\n  \"time_delivery_estimate\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer"

	payload := strings.NewReader("{\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_source\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_target\": {},\n  \"counterparty_alias\": {},\n  \"monetary_account_id\": \"\",\n  \"pay_in_reference\": \"\",\n  \"quote\": {\n    \"amount_fee\": {},\n    \"amount_source\": {},\n    \"amount_target\": {},\n    \"created\": \"\",\n    \"currency_source\": \"\",\n    \"currency_target\": \"\",\n    \"id\": 0,\n    \"quote_id\": \"\",\n    \"rate\": \"\",\n    \"time_delivery_estimate\": \"\",\n    \"time_expiry\": \"\",\n    \"updated\": \"\"\n  },\n  \"rate\": \"\",\n  \"recipient_id\": \"\",\n  \"reference\": \"\",\n  \"status\": \"\",\n  \"status_transferwise\": \"\",\n  \"status_transferwise_issue\": \"\",\n  \"sub_status\": \"\",\n  \"time_delivery_estimate\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 1387

{
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "amount_source": {
    "currency": "",
    "value": ""
  },
  "amount_target": {},
  "counterparty_alias": {},
  "monetary_account_id": "",
  "pay_in_reference": "",
  "quote": {
    "amount_fee": {},
    "amount_source": {},
    "amount_target": {},
    "created": "",
    "currency_source": "",
    "currency_target": "",
    "id": 0,
    "quote_id": "",
    "rate": "",
    "time_delivery_estimate": "",
    "time_expiry": "",
    "updated": ""
  },
  "rate": "",
  "recipient_id": "",
  "reference": "",
  "status": "",
  "status_transferwise": "",
  "status_transferwise_issue": "",
  "sub_status": "",
  "time_delivery_estimate": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_source\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_target\": {},\n  \"counterparty_alias\": {},\n  \"monetary_account_id\": \"\",\n  \"pay_in_reference\": \"\",\n  \"quote\": {\n    \"amount_fee\": {},\n    \"amount_source\": {},\n    \"amount_target\": {},\n    \"created\": \"\",\n    \"currency_source\": \"\",\n    \"currency_target\": \"\",\n    \"id\": 0,\n    \"quote_id\": \"\",\n    \"rate\": \"\",\n    \"time_delivery_estimate\": \"\",\n    \"time_expiry\": \"\",\n    \"updated\": \"\"\n  },\n  \"rate\": \"\",\n  \"recipient_id\": \"\",\n  \"reference\": \"\",\n  \"status\": \"\",\n  \"status_transferwise\": \"\",\n  \"status_transferwise_issue\": \"\",\n  \"sub_status\": \"\",\n  \"time_delivery_estimate\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_source\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_target\": {},\n  \"counterparty_alias\": {},\n  \"monetary_account_id\": \"\",\n  \"pay_in_reference\": \"\",\n  \"quote\": {\n    \"amount_fee\": {},\n    \"amount_source\": {},\n    \"amount_target\": {},\n    \"created\": \"\",\n    \"currency_source\": \"\",\n    \"currency_target\": \"\",\n    \"id\": 0,\n    \"quote_id\": \"\",\n    \"rate\": \"\",\n    \"time_delivery_estimate\": \"\",\n    \"time_expiry\": \"\",\n    \"updated\": \"\"\n  },\n  \"rate\": \"\",\n  \"recipient_id\": \"\",\n  \"reference\": \"\",\n  \"status\": \"\",\n  \"status_transferwise\": \"\",\n  \"status_transferwise_issue\": \"\",\n  \"sub_status\": \"\",\n  \"time_delivery_estimate\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_source\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_target\": {},\n  \"counterparty_alias\": {},\n  \"monetary_account_id\": \"\",\n  \"pay_in_reference\": \"\",\n  \"quote\": {\n    \"amount_fee\": {},\n    \"amount_source\": {},\n    \"amount_target\": {},\n    \"created\": \"\",\n    \"currency_source\": \"\",\n    \"currency_target\": \"\",\n    \"id\": 0,\n    \"quote_id\": \"\",\n    \"rate\": \"\",\n    \"time_delivery_estimate\": \"\",\n    \"time_expiry\": \"\",\n    \"updated\": \"\"\n  },\n  \"rate\": \"\",\n  \"recipient_id\": \"\",\n  \"reference\": \"\",\n  \"status\": \"\",\n  \"status_transferwise\": \"\",\n  \"status_transferwise_issue\": \"\",\n  \"sub_status\": \"\",\n  \"time_delivery_estimate\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_source\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_target\": {},\n  \"counterparty_alias\": {},\n  \"monetary_account_id\": \"\",\n  \"pay_in_reference\": \"\",\n  \"quote\": {\n    \"amount_fee\": {},\n    \"amount_source\": {},\n    \"amount_target\": {},\n    \"created\": \"\",\n    \"currency_source\": \"\",\n    \"currency_target\": \"\",\n    \"id\": 0,\n    \"quote_id\": \"\",\n    \"rate\": \"\",\n    \"time_delivery_estimate\": \"\",\n    \"time_expiry\": \"\",\n    \"updated\": \"\"\n  },\n  \"rate\": \"\",\n  \"recipient_id\": \"\",\n  \"reference\": \"\",\n  \"status\": \"\",\n  \"status_transferwise\": \"\",\n  \"status_transferwise_issue\": \"\",\n  \"sub_status\": \"\",\n  \"time_delivery_estimate\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  alias: {
    avatar: {
      anchor_uuid: '',
      image: [
        {
          attachment_public_uuid: '',
          content_type: '',
          height: 0,
          width: 0
        }
      ],
      style: '',
      uuid: ''
    },
    bunq_me: {
      name: '',
      service: '',
      type: '',
      value: ''
    },
    country: '',
    display_name: '',
    iban: '',
    is_light: false,
    label_user: {
      avatar: {},
      country: '',
      display_name: '',
      public_nick_name: '',
      uuid: ''
    },
    merchant_category_code: '',
    swift_account_number: '',
    swift_bic: '',
    transferwise_account_number: '',
    transferwise_bank_code: ''
  },
  amount_source: {
    currency: '',
    value: ''
  },
  amount_target: {},
  counterparty_alias: {},
  monetary_account_id: '',
  pay_in_reference: '',
  quote: {
    amount_fee: {},
    amount_source: {},
    amount_target: {},
    created: '',
    currency_source: '',
    currency_target: '',
    id: 0,
    quote_id: '',
    rate: '',
    time_delivery_estimate: '',
    time_expiry: '',
    updated: ''
  },
  rate: '',
  recipient_id: '',
  reference: '',
  status: '',
  status_transferwise: '',
  status_transferwise_issue: '',
  sub_status: '',
  time_delivery_estimate: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    alias: {
      avatar: {
        anchor_uuid: '',
        image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
        style: '',
        uuid: ''
      },
      bunq_me: {name: '', service: '', type: '', value: ''},
      country: '',
      display_name: '',
      iban: '',
      is_light: false,
      label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
      merchant_category_code: '',
      swift_account_number: '',
      swift_bic: '',
      transferwise_account_number: '',
      transferwise_bank_code: ''
    },
    amount_source: {currency: '', value: ''},
    amount_target: {},
    counterparty_alias: {},
    monetary_account_id: '',
    pay_in_reference: '',
    quote: {
      amount_fee: {},
      amount_source: {},
      amount_target: {},
      created: '',
      currency_source: '',
      currency_target: '',
      id: 0,
      quote_id: '',
      rate: '',
      time_delivery_estimate: '',
      time_expiry: '',
      updated: ''
    },
    rate: '',
    recipient_id: '',
    reference: '',
    status: '',
    status_transferwise: '',
    status_transferwise_issue: '',
    sub_status: '',
    time_delivery_estimate: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"amount_source":{"currency":"","value":""},"amount_target":{},"counterparty_alias":{},"monetary_account_id":"","pay_in_reference":"","quote":{"amount_fee":{},"amount_source":{},"amount_target":{},"created":"","currency_source":"","currency_target":"","id":0,"quote_id":"","rate":"","time_delivery_estimate":"","time_expiry":"","updated":""},"rate":"","recipient_id":"","reference":"","status":"","status_transferwise":"","status_transferwise_issue":"","sub_status":"","time_delivery_estimate":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "alias": {\n    "avatar": {\n      "anchor_uuid": "",\n      "image": [\n        {\n          "attachment_public_uuid": "",\n          "content_type": "",\n          "height": 0,\n          "width": 0\n        }\n      ],\n      "style": "",\n      "uuid": ""\n    },\n    "bunq_me": {\n      "name": "",\n      "service": "",\n      "type": "",\n      "value": ""\n    },\n    "country": "",\n    "display_name": "",\n    "iban": "",\n    "is_light": false,\n    "label_user": {\n      "avatar": {},\n      "country": "",\n      "display_name": "",\n      "public_nick_name": "",\n      "uuid": ""\n    },\n    "merchant_category_code": "",\n    "swift_account_number": "",\n    "swift_bic": "",\n    "transferwise_account_number": "",\n    "transferwise_bank_code": ""\n  },\n  "amount_source": {\n    "currency": "",\n    "value": ""\n  },\n  "amount_target": {},\n  "counterparty_alias": {},\n  "monetary_account_id": "",\n  "pay_in_reference": "",\n  "quote": {\n    "amount_fee": {},\n    "amount_source": {},\n    "amount_target": {},\n    "created": "",\n    "currency_source": "",\n    "currency_target": "",\n    "id": 0,\n    "quote_id": "",\n    "rate": "",\n    "time_delivery_estimate": "",\n    "time_expiry": "",\n    "updated": ""\n  },\n  "rate": "",\n  "recipient_id": "",\n  "reference": "",\n  "status": "",\n  "status_transferwise": "",\n  "status_transferwise_issue": "",\n  "sub_status": "",\n  "time_delivery_estimate": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_source\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_target\": {},\n  \"counterparty_alias\": {},\n  \"monetary_account_id\": \"\",\n  \"pay_in_reference\": \"\",\n  \"quote\": {\n    \"amount_fee\": {},\n    \"amount_source\": {},\n    \"amount_target\": {},\n    \"created\": \"\",\n    \"currency_source\": \"\",\n    \"currency_target\": \"\",\n    \"id\": 0,\n    \"quote_id\": \"\",\n    \"rate\": \"\",\n    \"time_delivery_estimate\": \"\",\n    \"time_expiry\": \"\",\n    \"updated\": \"\"\n  },\n  \"rate\": \"\",\n  \"recipient_id\": \"\",\n  \"reference\": \"\",\n  \"status\": \"\",\n  \"status_transferwise\": \"\",\n  \"status_transferwise_issue\": \"\",\n  \"sub_status\": \"\",\n  \"time_delivery_estimate\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  alias: {
    avatar: {
      anchor_uuid: '',
      image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
      style: '',
      uuid: ''
    },
    bunq_me: {name: '', service: '', type: '', value: ''},
    country: '',
    display_name: '',
    iban: '',
    is_light: false,
    label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
    merchant_category_code: '',
    swift_account_number: '',
    swift_bic: '',
    transferwise_account_number: '',
    transferwise_bank_code: ''
  },
  amount_source: {currency: '', value: ''},
  amount_target: {},
  counterparty_alias: {},
  monetary_account_id: '',
  pay_in_reference: '',
  quote: {
    amount_fee: {},
    amount_source: {},
    amount_target: {},
    created: '',
    currency_source: '',
    currency_target: '',
    id: 0,
    quote_id: '',
    rate: '',
    time_delivery_estimate: '',
    time_expiry: '',
    updated: ''
  },
  rate: '',
  recipient_id: '',
  reference: '',
  status: '',
  status_transferwise: '',
  status_transferwise_issue: '',
  sub_status: '',
  time_delivery_estimate: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    alias: {
      avatar: {
        anchor_uuid: '',
        image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
        style: '',
        uuid: ''
      },
      bunq_me: {name: '', service: '', type: '', value: ''},
      country: '',
      display_name: '',
      iban: '',
      is_light: false,
      label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
      merchant_category_code: '',
      swift_account_number: '',
      swift_bic: '',
      transferwise_account_number: '',
      transferwise_bank_code: ''
    },
    amount_source: {currency: '', value: ''},
    amount_target: {},
    counterparty_alias: {},
    monetary_account_id: '',
    pay_in_reference: '',
    quote: {
      amount_fee: {},
      amount_source: {},
      amount_target: {},
      created: '',
      currency_source: '',
      currency_target: '',
      id: 0,
      quote_id: '',
      rate: '',
      time_delivery_estimate: '',
      time_expiry: '',
      updated: ''
    },
    rate: '',
    recipient_id: '',
    reference: '',
    status: '',
    status_transferwise: '',
    status_transferwise_issue: '',
    sub_status: '',
    time_delivery_estimate: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  alias: {
    avatar: {
      anchor_uuid: '',
      image: [
        {
          attachment_public_uuid: '',
          content_type: '',
          height: 0,
          width: 0
        }
      ],
      style: '',
      uuid: ''
    },
    bunq_me: {
      name: '',
      service: '',
      type: '',
      value: ''
    },
    country: '',
    display_name: '',
    iban: '',
    is_light: false,
    label_user: {
      avatar: {},
      country: '',
      display_name: '',
      public_nick_name: '',
      uuid: ''
    },
    merchant_category_code: '',
    swift_account_number: '',
    swift_bic: '',
    transferwise_account_number: '',
    transferwise_bank_code: ''
  },
  amount_source: {
    currency: '',
    value: ''
  },
  amount_target: {},
  counterparty_alias: {},
  monetary_account_id: '',
  pay_in_reference: '',
  quote: {
    amount_fee: {},
    amount_source: {},
    amount_target: {},
    created: '',
    currency_source: '',
    currency_target: '',
    id: 0,
    quote_id: '',
    rate: '',
    time_delivery_estimate: '',
    time_expiry: '',
    updated: ''
  },
  rate: '',
  recipient_id: '',
  reference: '',
  status: '',
  status_transferwise: '',
  status_transferwise_issue: '',
  sub_status: '',
  time_delivery_estimate: ''
});

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}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    alias: {
      avatar: {
        anchor_uuid: '',
        image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
        style: '',
        uuid: ''
      },
      bunq_me: {name: '', service: '', type: '', value: ''},
      country: '',
      display_name: '',
      iban: '',
      is_light: false,
      label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
      merchant_category_code: '',
      swift_account_number: '',
      swift_bic: '',
      transferwise_account_number: '',
      transferwise_bank_code: ''
    },
    amount_source: {currency: '', value: ''},
    amount_target: {},
    counterparty_alias: {},
    monetary_account_id: '',
    pay_in_reference: '',
    quote: {
      amount_fee: {},
      amount_source: {},
      amount_target: {},
      created: '',
      currency_source: '',
      currency_target: '',
      id: 0,
      quote_id: '',
      rate: '',
      time_delivery_estimate: '',
      time_expiry: '',
      updated: ''
    },
    rate: '',
    recipient_id: '',
    reference: '',
    status: '',
    status_transferwise: '',
    status_transferwise_issue: '',
    sub_status: '',
    time_delivery_estimate: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"amount_source":{"currency":"","value":""},"amount_target":{},"counterparty_alias":{},"monetary_account_id":"","pay_in_reference":"","quote":{"amount_fee":{},"amount_source":{},"amount_target":{},"created":"","currency_source":"","currency_target":"","id":0,"quote_id":"","rate":"","time_delivery_estimate":"","time_expiry":"","updated":""},"rate":"","recipient_id":"","reference":"","status":"","status_transferwise":"","status_transferwise_issue":"","sub_status":"","time_delivery_estimate":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"alias": @{ @"avatar": @{ @"anchor_uuid": @"", @"image": @[ @{ @"attachment_public_uuid": @"", @"content_type": @"", @"height": @0, @"width": @0 } ], @"style": @"", @"uuid": @"" }, @"bunq_me": @{ @"name": @"", @"service": @"", @"type": @"", @"value": @"" }, @"country": @"", @"display_name": @"", @"iban": @"", @"is_light": @NO, @"label_user": @{ @"avatar": @{  }, @"country": @"", @"display_name": @"", @"public_nick_name": @"", @"uuid": @"" }, @"merchant_category_code": @"", @"swift_account_number": @"", @"swift_bic": @"", @"transferwise_account_number": @"", @"transferwise_bank_code": @"" },
                              @"amount_source": @{ @"currency": @"", @"value": @"" },
                              @"amount_target": @{  },
                              @"counterparty_alias": @{  },
                              @"monetary_account_id": @"",
                              @"pay_in_reference": @"",
                              @"quote": @{ @"amount_fee": @{  }, @"amount_source": @{  }, @"amount_target": @{  }, @"created": @"", @"currency_source": @"", @"currency_target": @"", @"id": @0, @"quote_id": @"", @"rate": @"", @"time_delivery_estimate": @"", @"time_expiry": @"", @"updated": @"" },
                              @"rate": @"",
                              @"recipient_id": @"",
                              @"reference": @"",
                              @"status": @"",
                              @"status_transferwise": @"",
                              @"status_transferwise_issue": @"",
                              @"sub_status": @"",
                              @"time_delivery_estimate": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_source\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_target\": {},\n  \"counterparty_alias\": {},\n  \"monetary_account_id\": \"\",\n  \"pay_in_reference\": \"\",\n  \"quote\": {\n    \"amount_fee\": {},\n    \"amount_source\": {},\n    \"amount_target\": {},\n    \"created\": \"\",\n    \"currency_source\": \"\",\n    \"currency_target\": \"\",\n    \"id\": 0,\n    \"quote_id\": \"\",\n    \"rate\": \"\",\n    \"time_delivery_estimate\": \"\",\n    \"time_expiry\": \"\",\n    \"updated\": \"\"\n  },\n  \"rate\": \"\",\n  \"recipient_id\": \"\",\n  \"reference\": \"\",\n  \"status\": \"\",\n  \"status_transferwise\": \"\",\n  \"status_transferwise_issue\": \"\",\n  \"sub_status\": \"\",\n  \"time_delivery_estimate\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'alias' => [
        'avatar' => [
                'anchor_uuid' => '',
                'image' => [
                                [
                                                                'attachment_public_uuid' => '',
                                                                'content_type' => '',
                                                                'height' => 0,
                                                                'width' => 0
                                ]
                ],
                'style' => '',
                'uuid' => ''
        ],
        'bunq_me' => [
                'name' => '',
                'service' => '',
                'type' => '',
                'value' => ''
        ],
        'country' => '',
        'display_name' => '',
        'iban' => '',
        'is_light' => null,
        'label_user' => [
                'avatar' => [
                                
                ],
                'country' => '',
                'display_name' => '',
                'public_nick_name' => '',
                'uuid' => ''
        ],
        'merchant_category_code' => '',
        'swift_account_number' => '',
        'swift_bic' => '',
        'transferwise_account_number' => '',
        'transferwise_bank_code' => ''
    ],
    'amount_source' => [
        'currency' => '',
        'value' => ''
    ],
    'amount_target' => [
        
    ],
    'counterparty_alias' => [
        
    ],
    'monetary_account_id' => '',
    'pay_in_reference' => '',
    'quote' => [
        'amount_fee' => [
                
        ],
        'amount_source' => [
                
        ],
        'amount_target' => [
                
        ],
        'created' => '',
        'currency_source' => '',
        'currency_target' => '',
        'id' => 0,
        'quote_id' => '',
        'rate' => '',
        'time_delivery_estimate' => '',
        'time_expiry' => '',
        'updated' => ''
    ],
    'rate' => '',
    'recipient_id' => '',
    'reference' => '',
    'status' => '',
    'status_transferwise' => '',
    'status_transferwise_issue' => '',
    'sub_status' => '',
    'time_delivery_estimate' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer', [
  'body' => '{
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "amount_source": {
    "currency": "",
    "value": ""
  },
  "amount_target": {},
  "counterparty_alias": {},
  "monetary_account_id": "",
  "pay_in_reference": "",
  "quote": {
    "amount_fee": {},
    "amount_source": {},
    "amount_target": {},
    "created": "",
    "currency_source": "",
    "currency_target": "",
    "id": 0,
    "quote_id": "",
    "rate": "",
    "time_delivery_estimate": "",
    "time_expiry": "",
    "updated": ""
  },
  "rate": "",
  "recipient_id": "",
  "reference": "",
  "status": "",
  "status_transferwise": "",
  "status_transferwise_issue": "",
  "sub_status": "",
  "time_delivery_estimate": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'alias' => [
    'avatar' => [
        'anchor_uuid' => '',
        'image' => [
                [
                                'attachment_public_uuid' => '',
                                'content_type' => '',
                                'height' => 0,
                                'width' => 0
                ]
        ],
        'style' => '',
        'uuid' => ''
    ],
    'bunq_me' => [
        'name' => '',
        'service' => '',
        'type' => '',
        'value' => ''
    ],
    'country' => '',
    'display_name' => '',
    'iban' => '',
    'is_light' => null,
    'label_user' => [
        'avatar' => [
                
        ],
        'country' => '',
        'display_name' => '',
        'public_nick_name' => '',
        'uuid' => ''
    ],
    'merchant_category_code' => '',
    'swift_account_number' => '',
    'swift_bic' => '',
    'transferwise_account_number' => '',
    'transferwise_bank_code' => ''
  ],
  'amount_source' => [
    'currency' => '',
    'value' => ''
  ],
  'amount_target' => [
    
  ],
  'counterparty_alias' => [
    
  ],
  'monetary_account_id' => '',
  'pay_in_reference' => '',
  'quote' => [
    'amount_fee' => [
        
    ],
    'amount_source' => [
        
    ],
    'amount_target' => [
        
    ],
    'created' => '',
    'currency_source' => '',
    'currency_target' => '',
    'id' => 0,
    'quote_id' => '',
    'rate' => '',
    'time_delivery_estimate' => '',
    'time_expiry' => '',
    'updated' => ''
  ],
  'rate' => '',
  'recipient_id' => '',
  'reference' => '',
  'status' => '',
  'status_transferwise' => '',
  'status_transferwise_issue' => '',
  'sub_status' => '',
  'time_delivery_estimate' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'alias' => [
    'avatar' => [
        'anchor_uuid' => '',
        'image' => [
                [
                                'attachment_public_uuid' => '',
                                'content_type' => '',
                                'height' => 0,
                                'width' => 0
                ]
        ],
        'style' => '',
        'uuid' => ''
    ],
    'bunq_me' => [
        'name' => '',
        'service' => '',
        'type' => '',
        'value' => ''
    ],
    'country' => '',
    'display_name' => '',
    'iban' => '',
    'is_light' => null,
    'label_user' => [
        'avatar' => [
                
        ],
        'country' => '',
        'display_name' => '',
        'public_nick_name' => '',
        'uuid' => ''
    ],
    'merchant_category_code' => '',
    'swift_account_number' => '',
    'swift_bic' => '',
    'transferwise_account_number' => '',
    'transferwise_bank_code' => ''
  ],
  'amount_source' => [
    'currency' => '',
    'value' => ''
  ],
  'amount_target' => [
    
  ],
  'counterparty_alias' => [
    
  ],
  'monetary_account_id' => '',
  'pay_in_reference' => '',
  'quote' => [
    'amount_fee' => [
        
    ],
    'amount_source' => [
        
    ],
    'amount_target' => [
        
    ],
    'created' => '',
    'currency_source' => '',
    'currency_target' => '',
    'id' => 0,
    'quote_id' => '',
    'rate' => '',
    'time_delivery_estimate' => '',
    'time_expiry' => '',
    'updated' => ''
  ],
  'rate' => '',
  'recipient_id' => '',
  'reference' => '',
  'status' => '',
  'status_transferwise' => '',
  'status_transferwise_issue' => '',
  'sub_status' => '',
  'time_delivery_estimate' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "amount_source": {
    "currency": "",
    "value": ""
  },
  "amount_target": {},
  "counterparty_alias": {},
  "monetary_account_id": "",
  "pay_in_reference": "",
  "quote": {
    "amount_fee": {},
    "amount_source": {},
    "amount_target": {},
    "created": "",
    "currency_source": "",
    "currency_target": "",
    "id": 0,
    "quote_id": "",
    "rate": "",
    "time_delivery_estimate": "",
    "time_expiry": "",
    "updated": ""
  },
  "rate": "",
  "recipient_id": "",
  "reference": "",
  "status": "",
  "status_transferwise": "",
  "status_transferwise_issue": "",
  "sub_status": "",
  "time_delivery_estimate": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "amount_source": {
    "currency": "",
    "value": ""
  },
  "amount_target": {},
  "counterparty_alias": {},
  "monetary_account_id": "",
  "pay_in_reference": "",
  "quote": {
    "amount_fee": {},
    "amount_source": {},
    "amount_target": {},
    "created": "",
    "currency_source": "",
    "currency_target": "",
    "id": 0,
    "quote_id": "",
    "rate": "",
    "time_delivery_estimate": "",
    "time_expiry": "",
    "updated": ""
  },
  "rate": "",
  "recipient_id": "",
  "reference": "",
  "status": "",
  "status_transferwise": "",
  "status_transferwise_issue": "",
  "sub_status": "",
  "time_delivery_estimate": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_source\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_target\": {},\n  \"counterparty_alias\": {},\n  \"monetary_account_id\": \"\",\n  \"pay_in_reference\": \"\",\n  \"quote\": {\n    \"amount_fee\": {},\n    \"amount_source\": {},\n    \"amount_target\": {},\n    \"created\": \"\",\n    \"currency_source\": \"\",\n    \"currency_target\": \"\",\n    \"id\": 0,\n    \"quote_id\": \"\",\n    \"rate\": \"\",\n    \"time_delivery_estimate\": \"\",\n    \"time_expiry\": \"\",\n    \"updated\": \"\"\n  },\n  \"rate\": \"\",\n  \"recipient_id\": \"\",\n  \"reference\": \"\",\n  \"status\": \"\",\n  \"status_transferwise\": \"\",\n  \"status_transferwise_issue\": \"\",\n  \"sub_status\": \"\",\n  \"time_delivery_estimate\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer"

payload = {
    "alias": {
        "avatar": {
            "anchor_uuid": "",
            "image": [
                {
                    "attachment_public_uuid": "",
                    "content_type": "",
                    "height": 0,
                    "width": 0
                }
            ],
            "style": "",
            "uuid": ""
        },
        "bunq_me": {
            "name": "",
            "service": "",
            "type": "",
            "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": False,
        "label_user": {
            "avatar": {},
            "country": "",
            "display_name": "",
            "public_nick_name": "",
            "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
    },
    "amount_source": {
        "currency": "",
        "value": ""
    },
    "amount_target": {},
    "counterparty_alias": {},
    "monetary_account_id": "",
    "pay_in_reference": "",
    "quote": {
        "amount_fee": {},
        "amount_source": {},
        "amount_target": {},
        "created": "",
        "currency_source": "",
        "currency_target": "",
        "id": 0,
        "quote_id": "",
        "rate": "",
        "time_delivery_estimate": "",
        "time_expiry": "",
        "updated": ""
    },
    "rate": "",
    "recipient_id": "",
    "reference": "",
    "status": "",
    "status_transferwise": "",
    "status_transferwise_issue": "",
    "sub_status": "",
    "time_delivery_estimate": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer"

payload <- "{\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_source\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_target\": {},\n  \"counterparty_alias\": {},\n  \"monetary_account_id\": \"\",\n  \"pay_in_reference\": \"\",\n  \"quote\": {\n    \"amount_fee\": {},\n    \"amount_source\": {},\n    \"amount_target\": {},\n    \"created\": \"\",\n    \"currency_source\": \"\",\n    \"currency_target\": \"\",\n    \"id\": 0,\n    \"quote_id\": \"\",\n    \"rate\": \"\",\n    \"time_delivery_estimate\": \"\",\n    \"time_expiry\": \"\",\n    \"updated\": \"\"\n  },\n  \"rate\": \"\",\n  \"recipient_id\": \"\",\n  \"reference\": \"\",\n  \"status\": \"\",\n  \"status_transferwise\": \"\",\n  \"status_transferwise_issue\": \"\",\n  \"sub_status\": \"\",\n  \"time_delivery_estimate\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_source\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_target\": {},\n  \"counterparty_alias\": {},\n  \"monetary_account_id\": \"\",\n  \"pay_in_reference\": \"\",\n  \"quote\": {\n    \"amount_fee\": {},\n    \"amount_source\": {},\n    \"amount_target\": {},\n    \"created\": \"\",\n    \"currency_source\": \"\",\n    \"currency_target\": \"\",\n    \"id\": 0,\n    \"quote_id\": \"\",\n    \"rate\": \"\",\n    \"time_delivery_estimate\": \"\",\n    \"time_expiry\": \"\",\n    \"updated\": \"\"\n  },\n  \"rate\": \"\",\n  \"recipient_id\": \"\",\n  \"reference\": \"\",\n  \"status\": \"\",\n  \"status_transferwise\": \"\",\n  \"status_transferwise_issue\": \"\",\n  \"sub_status\": \"\",\n  \"time_delivery_estimate\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"alias\": {\n    \"avatar\": {\n      \"anchor_uuid\": \"\",\n      \"image\": [\n        {\n          \"attachment_public_uuid\": \"\",\n          \"content_type\": \"\",\n          \"height\": 0,\n          \"width\": 0\n        }\n      ],\n      \"style\": \"\",\n      \"uuid\": \"\"\n    },\n    \"bunq_me\": {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    },\n    \"country\": \"\",\n    \"display_name\": \"\",\n    \"iban\": \"\",\n    \"is_light\": false,\n    \"label_user\": {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    },\n    \"merchant_category_code\": \"\",\n    \"swift_account_number\": \"\",\n    \"swift_bic\": \"\",\n    \"transferwise_account_number\": \"\",\n    \"transferwise_bank_code\": \"\"\n  },\n  \"amount_source\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"amount_target\": {},\n  \"counterparty_alias\": {},\n  \"monetary_account_id\": \"\",\n  \"pay_in_reference\": \"\",\n  \"quote\": {\n    \"amount_fee\": {},\n    \"amount_source\": {},\n    \"amount_target\": {},\n    \"created\": \"\",\n    \"currency_source\": \"\",\n    \"currency_target\": \"\",\n    \"id\": 0,\n    \"quote_id\": \"\",\n    \"rate\": \"\",\n    \"time_delivery_estimate\": \"\",\n    \"time_expiry\": \"\",\n    \"updated\": \"\"\n  },\n  \"rate\": \"\",\n  \"recipient_id\": \"\",\n  \"reference\": \"\",\n  \"status\": \"\",\n  \"status_transferwise\": \"\",\n  \"status_transferwise_issue\": \"\",\n  \"sub_status\": \"\",\n  \"time_delivery_estimate\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer";

    let payload = json!({
        "alias": json!({
            "avatar": json!({
                "anchor_uuid": "",
                "image": (
                    json!({
                        "attachment_public_uuid": "",
                        "content_type": "",
                        "height": 0,
                        "width": 0
                    })
                ),
                "style": "",
                "uuid": ""
            }),
            "bunq_me": json!({
                "name": "",
                "service": "",
                "type": "",
                "value": ""
            }),
            "country": "",
            "display_name": "",
            "iban": "",
            "is_light": false,
            "label_user": json!({
                "avatar": json!({}),
                "country": "",
                "display_name": "",
                "public_nick_name": "",
                "uuid": ""
            }),
            "merchant_category_code": "",
            "swift_account_number": "",
            "swift_bic": "",
            "transferwise_account_number": "",
            "transferwise_bank_code": ""
        }),
        "amount_source": json!({
            "currency": "",
            "value": ""
        }),
        "amount_target": json!({}),
        "counterparty_alias": json!({}),
        "monetary_account_id": "",
        "pay_in_reference": "",
        "quote": json!({
            "amount_fee": json!({}),
            "amount_source": json!({}),
            "amount_target": json!({}),
            "created": "",
            "currency_source": "",
            "currency_target": "",
            "id": 0,
            "quote_id": "",
            "rate": "",
            "time_delivery_estimate": "",
            "time_expiry": "",
            "updated": ""
        }),
        "rate": "",
        "recipient_id": "",
        "reference": "",
        "status": "",
        "status_transferwise": "",
        "status_transferwise_issue": "",
        "sub_status": "",
        "time_delivery_estimate": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "amount_source": {
    "currency": "",
    "value": ""
  },
  "amount_target": {},
  "counterparty_alias": {},
  "monetary_account_id": "",
  "pay_in_reference": "",
  "quote": {
    "amount_fee": {},
    "amount_source": {},
    "amount_target": {},
    "created": "",
    "currency_source": "",
    "currency_target": "",
    "id": 0,
    "quote_id": "",
    "rate": "",
    "time_delivery_estimate": "",
    "time_expiry": "",
    "updated": ""
  },
  "rate": "",
  "recipient_id": "",
  "reference": "",
  "status": "",
  "status_transferwise": "",
  "status_transferwise_issue": "",
  "sub_status": "",
  "time_delivery_estimate": ""
}'
echo '{
  "alias": {
    "avatar": {
      "anchor_uuid": "",
      "image": [
        {
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        }
      ],
      "style": "",
      "uuid": ""
    },
    "bunq_me": {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    },
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    },
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  },
  "amount_source": {
    "currency": "",
    "value": ""
  },
  "amount_target": {},
  "counterparty_alias": {},
  "monetary_account_id": "",
  "pay_in_reference": "",
  "quote": {
    "amount_fee": {},
    "amount_source": {},
    "amount_target": {},
    "created": "",
    "currency_source": "",
    "currency_target": "",
    "id": 0,
    "quote_id": "",
    "rate": "",
    "time_delivery_estimate": "",
    "time_expiry": "",
    "updated": ""
  },
  "rate": "",
  "recipient_id": "",
  "reference": "",
  "status": "",
  "status_transferwise": "",
  "status_transferwise_issue": "",
  "sub_status": "",
  "time_delivery_estimate": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "alias": {\n    "avatar": {\n      "anchor_uuid": "",\n      "image": [\n        {\n          "attachment_public_uuid": "",\n          "content_type": "",\n          "height": 0,\n          "width": 0\n        }\n      ],\n      "style": "",\n      "uuid": ""\n    },\n    "bunq_me": {\n      "name": "",\n      "service": "",\n      "type": "",\n      "value": ""\n    },\n    "country": "",\n    "display_name": "",\n    "iban": "",\n    "is_light": false,\n    "label_user": {\n      "avatar": {},\n      "country": "",\n      "display_name": "",\n      "public_nick_name": "",\n      "uuid": ""\n    },\n    "merchant_category_code": "",\n    "swift_account_number": "",\n    "swift_bic": "",\n    "transferwise_account_number": "",\n    "transferwise_bank_code": ""\n  },\n  "amount_source": {\n    "currency": "",\n    "value": ""\n  },\n  "amount_target": {},\n  "counterparty_alias": {},\n  "monetary_account_id": "",\n  "pay_in_reference": "",\n  "quote": {\n    "amount_fee": {},\n    "amount_source": {},\n    "amount_target": {},\n    "created": "",\n    "currency_source": "",\n    "currency_target": "",\n    "id": 0,\n    "quote_id": "",\n    "rate": "",\n    "time_delivery_estimate": "",\n    "time_expiry": "",\n    "updated": ""\n  },\n  "rate": "",\n  "recipient_id": "",\n  "reference": "",\n  "status": "",\n  "status_transferwise": "",\n  "status_transferwise_issue": "",\n  "sub_status": "",\n  "time_delivery_estimate": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "alias": [
    "avatar": [
      "anchor_uuid": "",
      "image": [
        [
          "attachment_public_uuid": "",
          "content_type": "",
          "height": 0,
          "width": 0
        ]
      ],
      "style": "",
      "uuid": ""
    ],
    "bunq_me": [
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    ],
    "country": "",
    "display_name": "",
    "iban": "",
    "is_light": false,
    "label_user": [
      "avatar": [],
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    ],
    "merchant_category_code": "",
    "swift_account_number": "",
    "swift_bic": "",
    "transferwise_account_number": "",
    "transferwise_bank_code": ""
  ],
  "amount_source": [
    "currency": "",
    "value": ""
  ],
  "amount_target": [],
  "counterparty_alias": [],
  "monetary_account_id": "",
  "pay_in_reference": "",
  "quote": [
    "amount_fee": [],
    "amount_source": [],
    "amount_target": [],
    "created": "",
    "currency_source": "",
    "currency_target": "",
    "id": 0,
    "quote_id": "",
    "rate": "",
    "time_delivery_estimate": "",
    "time_expiry": "",
    "updated": ""
  ],
  "rate": "",
  "recipient_id": "",
  "reference": "",
  "status": "",
  "status_transferwise": "",
  "status_transferwise_issue": "",
  "sub_status": "",
  "time_delivery_estimate": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_TransferwiseTransfer_for_User_TransferwiseQuote
{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
transferwise-quoteID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer" {:headers {:user-agent ""
                                                                                                                                 :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_TransferwiseTransfer_for_User_TransferwiseQuote
{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
transferwise-quoteID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer/:itemId" {:headers {:user-agent ""
                                                                                                                                         :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_TransferwiseTransferRequirement_for_User_TransferwiseQuote
{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer-requirement
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
transferwise-quoteID
BODY json

{
  "detail": [
    {
      "group": {
        "display_format": "",
        "example": "",
        "key": "",
        "max_length": "",
        "min_length": "",
        "name": "",
        "refresh_requirements_on_change": false,
        "required": false,
        "type": "",
        "validation_async": {
          "params": {
            "key": "",
            "parameter_name": "",
            "required": false
          },
          "url": ""
        },
        "validation_regexp": "",
        "values_allowed": {
          "key": "",
          "name": ""
        }
      },
      "key": "",
      "name": "",
      "value": ""
    }
  ],
  "recipient_id": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer-requirement");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"recipient_id\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer-requirement" {:headers {:user-agent ""
                                                                                                                                              :x-bunq-client-authentication ""}
                                                                                                                                    :content-type :json
                                                                                                                                    :form-params {:detail [{:group {:display_format ""
                                                                                                                                                                    :example ""
                                                                                                                                                                    :key ""
                                                                                                                                                                    :max_length ""
                                                                                                                                                                    :min_length ""
                                                                                                                                                                    :name ""
                                                                                                                                                                    :refresh_requirements_on_change false
                                                                                                                                                                    :required false
                                                                                                                                                                    :type ""
                                                                                                                                                                    :validation_async {:params {:key ""
                                                                                                                                                                                                :parameter_name ""
                                                                                                                                                                                                :required false}
                                                                                                                                                                                       :url ""}
                                                                                                                                                                    :validation_regexp ""
                                                                                                                                                                    :values_allowed {:key ""
                                                                                                                                                                                     :name ""}}
                                                                                                                                                            :key ""
                                                                                                                                                            :name ""
                                                                                                                                                            :value ""}]
                                                                                                                                                  :recipient_id ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer-requirement"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"recipient_id\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer-requirement"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"recipient_id\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer-requirement");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"recipient_id\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer-requirement"

	payload := strings.NewReader("{\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"recipient_id\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer-requirement HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 670

{
  "detail": [
    {
      "group": {
        "display_format": "",
        "example": "",
        "key": "",
        "max_length": "",
        "min_length": "",
        "name": "",
        "refresh_requirements_on_change": false,
        "required": false,
        "type": "",
        "validation_async": {
          "params": {
            "key": "",
            "parameter_name": "",
            "required": false
          },
          "url": ""
        },
        "validation_regexp": "",
        "values_allowed": {
          "key": "",
          "name": ""
        }
      },
      "key": "",
      "name": "",
      "value": ""
    }
  ],
  "recipient_id": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer-requirement")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"recipient_id\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer-requirement"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"recipient_id\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"recipient_id\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer-requirement")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer-requirement")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"recipient_id\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  detail: [
    {
      group: {
        display_format: '',
        example: '',
        key: '',
        max_length: '',
        min_length: '',
        name: '',
        refresh_requirements_on_change: false,
        required: false,
        type: '',
        validation_async: {
          params: {
            key: '',
            parameter_name: '',
            required: false
          },
          url: ''
        },
        validation_regexp: '',
        values_allowed: {
          key: '',
          name: ''
        }
      },
      key: '',
      name: '',
      value: ''
    }
  ],
  recipient_id: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer-requirement');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer-requirement',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    detail: [
      {
        group: {
          display_format: '',
          example: '',
          key: '',
          max_length: '',
          min_length: '',
          name: '',
          refresh_requirements_on_change: false,
          required: false,
          type: '',
          validation_async: {params: {key: '', parameter_name: '', required: false}, url: ''},
          validation_regexp: '',
          values_allowed: {key: '', name: ''}
        },
        key: '',
        name: '',
        value: ''
      }
    ],
    recipient_id: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer-requirement';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"detail":[{"group":{"display_format":"","example":"","key":"","max_length":"","min_length":"","name":"","refresh_requirements_on_change":false,"required":false,"type":"","validation_async":{"params":{"key":"","parameter_name":"","required":false},"url":""},"validation_regexp":"","values_allowed":{"key":"","name":""}},"key":"","name":"","value":""}],"recipient_id":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer-requirement',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "detail": [\n    {\n      "group": {\n        "display_format": "",\n        "example": "",\n        "key": "",\n        "max_length": "",\n        "min_length": "",\n        "name": "",\n        "refresh_requirements_on_change": false,\n        "required": false,\n        "type": "",\n        "validation_async": {\n          "params": {\n            "key": "",\n            "parameter_name": "",\n            "required": false\n          },\n          "url": ""\n        },\n        "validation_regexp": "",\n        "values_allowed": {\n          "key": "",\n          "name": ""\n        }\n      },\n      "key": "",\n      "name": "",\n      "value": ""\n    }\n  ],\n  "recipient_id": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"recipient_id\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer-requirement")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer-requirement',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  detail: [
    {
      group: {
        display_format: '',
        example: '',
        key: '',
        max_length: '',
        min_length: '',
        name: '',
        refresh_requirements_on_change: false,
        required: false,
        type: '',
        validation_async: {params: {key: '', parameter_name: '', required: false}, url: ''},
        validation_regexp: '',
        values_allowed: {key: '', name: ''}
      },
      key: '',
      name: '',
      value: ''
    }
  ],
  recipient_id: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer-requirement',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    detail: [
      {
        group: {
          display_format: '',
          example: '',
          key: '',
          max_length: '',
          min_length: '',
          name: '',
          refresh_requirements_on_change: false,
          required: false,
          type: '',
          validation_async: {params: {key: '', parameter_name: '', required: false}, url: ''},
          validation_regexp: '',
          values_allowed: {key: '', name: ''}
        },
        key: '',
        name: '',
        value: ''
      }
    ],
    recipient_id: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer-requirement');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  detail: [
    {
      group: {
        display_format: '',
        example: '',
        key: '',
        max_length: '',
        min_length: '',
        name: '',
        refresh_requirements_on_change: false,
        required: false,
        type: '',
        validation_async: {
          params: {
            key: '',
            parameter_name: '',
            required: false
          },
          url: ''
        },
        validation_regexp: '',
        values_allowed: {
          key: '',
          name: ''
        }
      },
      key: '',
      name: '',
      value: ''
    }
  ],
  recipient_id: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer-requirement',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    detail: [
      {
        group: {
          display_format: '',
          example: '',
          key: '',
          max_length: '',
          min_length: '',
          name: '',
          refresh_requirements_on_change: false,
          required: false,
          type: '',
          validation_async: {params: {key: '', parameter_name: '', required: false}, url: ''},
          validation_regexp: '',
          values_allowed: {key: '', name: ''}
        },
        key: '',
        name: '',
        value: ''
      }
    ],
    recipient_id: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer-requirement';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"detail":[{"group":{"display_format":"","example":"","key":"","max_length":"","min_length":"","name":"","refresh_requirements_on_change":false,"required":false,"type":"","validation_async":{"params":{"key":"","parameter_name":"","required":false},"url":""},"validation_regexp":"","values_allowed":{"key":"","name":""}},"key":"","name":"","value":""}],"recipient_id":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"detail": @[ @{ @"group": @{ @"display_format": @"", @"example": @"", @"key": @"", @"max_length": @"", @"min_length": @"", @"name": @"", @"refresh_requirements_on_change": @NO, @"required": @NO, @"type": @"", @"validation_async": @{ @"params": @{ @"key": @"", @"parameter_name": @"", @"required": @NO }, @"url": @"" }, @"validation_regexp": @"", @"values_allowed": @{ @"key": @"", @"name": @"" } }, @"key": @"", @"name": @"", @"value": @"" } ],
                              @"recipient_id": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer-requirement"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer-requirement" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"recipient_id\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer-requirement",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'detail' => [
        [
                'group' => [
                                'display_format' => '',
                                'example' => '',
                                'key' => '',
                                'max_length' => '',
                                'min_length' => '',
                                'name' => '',
                                'refresh_requirements_on_change' => null,
                                'required' => null,
                                'type' => '',
                                'validation_async' => [
                                                                'params' => [
                                                                                                                                'key' => '',
                                                                                                                                'parameter_name' => '',
                                                                                                                                'required' => null
                                                                ],
                                                                'url' => ''
                                ],
                                'validation_regexp' => '',
                                'values_allowed' => [
                                                                'key' => '',
                                                                'name' => ''
                                ]
                ],
                'key' => '',
                'name' => '',
                'value' => ''
        ]
    ],
    'recipient_id' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer-requirement', [
  'body' => '{
  "detail": [
    {
      "group": {
        "display_format": "",
        "example": "",
        "key": "",
        "max_length": "",
        "min_length": "",
        "name": "",
        "refresh_requirements_on_change": false,
        "required": false,
        "type": "",
        "validation_async": {
          "params": {
            "key": "",
            "parameter_name": "",
            "required": false
          },
          "url": ""
        },
        "validation_regexp": "",
        "values_allowed": {
          "key": "",
          "name": ""
        }
      },
      "key": "",
      "name": "",
      "value": ""
    }
  ],
  "recipient_id": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer-requirement');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'detail' => [
    [
        'group' => [
                'display_format' => '',
                'example' => '',
                'key' => '',
                'max_length' => '',
                'min_length' => '',
                'name' => '',
                'refresh_requirements_on_change' => null,
                'required' => null,
                'type' => '',
                'validation_async' => [
                                'params' => [
                                                                'key' => '',
                                                                'parameter_name' => '',
                                                                'required' => null
                                ],
                                'url' => ''
                ],
                'validation_regexp' => '',
                'values_allowed' => [
                                'key' => '',
                                'name' => ''
                ]
        ],
        'key' => '',
        'name' => '',
        'value' => ''
    ]
  ],
  'recipient_id' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'detail' => [
    [
        'group' => [
                'display_format' => '',
                'example' => '',
                'key' => '',
                'max_length' => '',
                'min_length' => '',
                'name' => '',
                'refresh_requirements_on_change' => null,
                'required' => null,
                'type' => '',
                'validation_async' => [
                                'params' => [
                                                                'key' => '',
                                                                'parameter_name' => '',
                                                                'required' => null
                                ],
                                'url' => ''
                ],
                'validation_regexp' => '',
                'values_allowed' => [
                                'key' => '',
                                'name' => ''
                ]
        ],
        'key' => '',
        'name' => '',
        'value' => ''
    ]
  ],
  'recipient_id' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer-requirement');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer-requirement' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "detail": [
    {
      "group": {
        "display_format": "",
        "example": "",
        "key": "",
        "max_length": "",
        "min_length": "",
        "name": "",
        "refresh_requirements_on_change": false,
        "required": false,
        "type": "",
        "validation_async": {
          "params": {
            "key": "",
            "parameter_name": "",
            "required": false
          },
          "url": ""
        },
        "validation_regexp": "",
        "values_allowed": {
          "key": "",
          "name": ""
        }
      },
      "key": "",
      "name": "",
      "value": ""
    }
  ],
  "recipient_id": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer-requirement' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "detail": [
    {
      "group": {
        "display_format": "",
        "example": "",
        "key": "",
        "max_length": "",
        "min_length": "",
        "name": "",
        "refresh_requirements_on_change": false,
        "required": false,
        "type": "",
        "validation_async": {
          "params": {
            "key": "",
            "parameter_name": "",
            "required": false
          },
          "url": ""
        },
        "validation_regexp": "",
        "values_allowed": {
          "key": "",
          "name": ""
        }
      },
      "key": "",
      "name": "",
      "value": ""
    }
  ],
  "recipient_id": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"recipient_id\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer-requirement", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer-requirement"

payload = {
    "detail": [
        {
            "group": {
                "display_format": "",
                "example": "",
                "key": "",
                "max_length": "",
                "min_length": "",
                "name": "",
                "refresh_requirements_on_change": False,
                "required": False,
                "type": "",
                "validation_async": {
                    "params": {
                        "key": "",
                        "parameter_name": "",
                        "required": False
                    },
                    "url": ""
                },
                "validation_regexp": "",
                "values_allowed": {
                    "key": "",
                    "name": ""
                }
            },
            "key": "",
            "name": "",
            "value": ""
        }
    ],
    "recipient_id": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer-requirement"

payload <- "{\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"recipient_id\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer-requirement")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"recipient_id\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer-requirement') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"detail\": [\n    {\n      \"group\": {\n        \"display_format\": \"\",\n        \"example\": \"\",\n        \"key\": \"\",\n        \"max_length\": \"\",\n        \"min_length\": \"\",\n        \"name\": \"\",\n        \"refresh_requirements_on_change\": false,\n        \"required\": false,\n        \"type\": \"\",\n        \"validation_async\": {\n          \"params\": {\n            \"key\": \"\",\n            \"parameter_name\": \"\",\n            \"required\": false\n          },\n          \"url\": \"\"\n        },\n        \"validation_regexp\": \"\",\n        \"values_allowed\": {\n          \"key\": \"\",\n          \"name\": \"\"\n        }\n      },\n      \"key\": \"\",\n      \"name\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"recipient_id\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer-requirement";

    let payload = json!({
        "detail": (
            json!({
                "group": json!({
                    "display_format": "",
                    "example": "",
                    "key": "",
                    "max_length": "",
                    "min_length": "",
                    "name": "",
                    "refresh_requirements_on_change": false,
                    "required": false,
                    "type": "",
                    "validation_async": json!({
                        "params": json!({
                            "key": "",
                            "parameter_name": "",
                            "required": false
                        }),
                        "url": ""
                    }),
                    "validation_regexp": "",
                    "values_allowed": json!({
                        "key": "",
                        "name": ""
                    })
                }),
                "key": "",
                "name": "",
                "value": ""
            })
        ),
        "recipient_id": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer-requirement \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "detail": [
    {
      "group": {
        "display_format": "",
        "example": "",
        "key": "",
        "max_length": "",
        "min_length": "",
        "name": "",
        "refresh_requirements_on_change": false,
        "required": false,
        "type": "",
        "validation_async": {
          "params": {
            "key": "",
            "parameter_name": "",
            "required": false
          },
          "url": ""
        },
        "validation_regexp": "",
        "values_allowed": {
          "key": "",
          "name": ""
        }
      },
      "key": "",
      "name": "",
      "value": ""
    }
  ],
  "recipient_id": ""
}'
echo '{
  "detail": [
    {
      "group": {
        "display_format": "",
        "example": "",
        "key": "",
        "max_length": "",
        "min_length": "",
        "name": "",
        "refresh_requirements_on_change": false,
        "required": false,
        "type": "",
        "validation_async": {
          "params": {
            "key": "",
            "parameter_name": "",
            "required": false
          },
          "url": ""
        },
        "validation_regexp": "",
        "values_allowed": {
          "key": "",
          "name": ""
        }
      },
      "key": "",
      "name": "",
      "value": ""
    }
  ],
  "recipient_id": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer-requirement \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "detail": [\n    {\n      "group": {\n        "display_format": "",\n        "example": "",\n        "key": "",\n        "max_length": "",\n        "min_length": "",\n        "name": "",\n        "refresh_requirements_on_change": false,\n        "required": false,\n        "type": "",\n        "validation_async": {\n          "params": {\n            "key": "",\n            "parameter_name": "",\n            "required": false\n          },\n          "url": ""\n        },\n        "validation_regexp": "",\n        "values_allowed": {\n          "key": "",\n          "name": ""\n        }\n      },\n      "key": "",\n      "name": "",\n      "value": ""\n    }\n  ],\n  "recipient_id": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer-requirement
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "detail": [
    [
      "group": [
        "display_format": "",
        "example": "",
        "key": "",
        "max_length": "",
        "min_length": "",
        "name": "",
        "refresh_requirements_on_change": false,
        "required": false,
        "type": "",
        "validation_async": [
          "params": [
            "key": "",
            "parameter_name": "",
            "required": false
          ],
          "url": ""
        ],
        "validation_regexp": "",
        "values_allowed": [
          "key": "",
          "name": ""
        ]
      ],
      "key": "",
      "name": "",
      "value": ""
    ]
  ],
  "recipient_id": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/transferwise-quote/:transferwise-quoteID/transferwise-transfer-requirement")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_TransferwiseUser_for_User
{{baseUrl}}/user/:userID/transferwise-user
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
BODY json

{
  "oauth_code": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/transferwise-user");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"oauth_code\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/transferwise-user" {:headers {:user-agent ""
                                                                                     :x-bunq-client-authentication ""}
                                                                           :content-type :json
                                                                           :form-params {:oauth_code ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/transferwise-user"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"oauth_code\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/transferwise-user"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"oauth_code\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/transferwise-user");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"oauth_code\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/transferwise-user"

	payload := strings.NewReader("{\n  \"oauth_code\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/transferwise-user HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 22

{
  "oauth_code": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/transferwise-user")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"oauth_code\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/transferwise-user"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"oauth_code\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"oauth_code\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/transferwise-user")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/transferwise-user")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"oauth_code\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  oauth_code: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/transferwise-user');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/transferwise-user',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {oauth_code: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/transferwise-user';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"oauth_code":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/transferwise-user',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "oauth_code": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"oauth_code\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/transferwise-user")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/transferwise-user',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({oauth_code: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/transferwise-user',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {oauth_code: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/transferwise-user');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  oauth_code: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/transferwise-user',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {oauth_code: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/transferwise-user';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"oauth_code":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"oauth_code": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/transferwise-user"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/transferwise-user" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"oauth_code\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/transferwise-user",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'oauth_code' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/transferwise-user', [
  'body' => '{
  "oauth_code": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/transferwise-user');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'oauth_code' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'oauth_code' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/transferwise-user');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/transferwise-user' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "oauth_code": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/transferwise-user' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "oauth_code": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"oauth_code\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/transferwise-user", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/transferwise-user"

payload = { "oauth_code": "" }
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/transferwise-user"

payload <- "{\n  \"oauth_code\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/transferwise-user")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"oauth_code\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/transferwise-user') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"oauth_code\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/transferwise-user";

    let payload = json!({"oauth_code": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/transferwise-user \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "oauth_code": ""
}'
echo '{
  "oauth_code": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/transferwise-user \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "oauth_code": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/transferwise-user
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = ["oauth_code": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/transferwise-user")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_TransferwiseUser_for_User
{{baseUrl}}/user/:userID/transferwise-user
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/transferwise-user");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/transferwise-user" {:headers {:user-agent ""
                                                                                    :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/transferwise-user"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/transferwise-user"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/transferwise-user");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/transferwise-user"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/transferwise-user HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/transferwise-user")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/transferwise-user"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/transferwise-user")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/transferwise-user")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/transferwise-user');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/transferwise-user',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/transferwise-user';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/transferwise-user',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/transferwise-user")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/transferwise-user',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/transferwise-user',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/transferwise-user');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/transferwise-user',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/transferwise-user';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/transferwise-user"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/transferwise-user" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/transferwise-user",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/transferwise-user', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/transferwise-user');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/transferwise-user');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/transferwise-user' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/transferwise-user' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/transferwise-user", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/transferwise-user"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/transferwise-user"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/transferwise-user")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/transferwise-user') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/transferwise-user";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/transferwise-user \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/transferwise-user \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/transferwise-user
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/transferwise-user")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"description\": \"\",\n  \"payments\": [\n    {\n      \"address_billing\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"address_shipping\": {},\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"balance_after_mutation\": {},\n      \"batch_id\": 0,\n      \"bunqto_expiry\": \"\",\n      \"bunqto_share_url\": \"\",\n      \"bunqto_status\": \"\",\n      \"bunqto_sub_status\": \"\",\n      \"bunqto_time_responded\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"geolocation\": {\n        \"altitude\": 0,\n        \"latitude\": 0,\n        \"longitude\": 0,\n        \"radius\": 0\n      },\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"monetary_account_id\": 0,\n      \"payment_auto_allocate_instance\": {\n        \"created\": \"\",\n        \"error_message\": [],\n        \"id\": 0,\n        \"payment_auto_allocate_id\": 0,\n        \"payment_batch\": {\n          \"payments\": {\n            \"Payment\": []\n          }\n        },\n        \"payment_id\": 0,\n        \"status\": \"\",\n        \"updated\": \"\"\n      },\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"scheduled_id\": 0,\n      \"sub_type\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"reference\": \"\",\n  \"type\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction" {:headers {:user-agent ""
                                                                                                                              :x-bunq-client-authentication ""}
                                                                                                                    :content-type :json
                                                                                                                    :form-params {:description ""
                                                                                                                                  :payments [{:address_billing {:city ""
                                                                                                                                                                :country ""
                                                                                                                                                                :extra ""
                                                                                                                                                                :house_number ""
                                                                                                                                                                :is_user_address_updated false
                                                                                                                                                                :mailbox_name ""
                                                                                                                                                                :po_box ""
                                                                                                                                                                :postal_code ""
                                                                                                                                                                :province ""
                                                                                                                                                                :street ""}
                                                                                                                                              :address_shipping {}
                                                                                                                                              :alias {:avatar {:anchor_uuid ""
                                                                                                                                                               :image [{:attachment_public_uuid ""
                                                                                                                                                                        :content_type ""
                                                                                                                                                                        :height 0
                                                                                                                                                                        :width 0}]
                                                                                                                                                               :style ""
                                                                                                                                                               :uuid ""}
                                                                                                                                                      :bunq_me {:name ""
                                                                                                                                                                :service ""
                                                                                                                                                                :type ""
                                                                                                                                                                :value ""}
                                                                                                                                                      :country ""
                                                                                                                                                      :display_name ""
                                                                                                                                                      :iban ""
                                                                                                                                                      :is_light false
                                                                                                                                                      :label_user {:avatar {}
                                                                                                                                                                   :country ""
                                                                                                                                                                   :display_name ""
                                                                                                                                                                   :public_nick_name ""
                                                                                                                                                                   :uuid ""}
                                                                                                                                                      :merchant_category_code ""
                                                                                                                                                      :swift_account_number ""
                                                                                                                                                      :swift_bic ""
                                                                                                                                                      :transferwise_account_number ""
                                                                                                                                                      :transferwise_bank_code ""}
                                                                                                                                              :allow_bunqto false
                                                                                                                                              :amount {:currency ""
                                                                                                                                                       :value ""}
                                                                                                                                              :attachment [{:id 0
                                                                                                                                                            :monetary_account_id 0}]
                                                                                                                                              :balance_after_mutation {}
                                                                                                                                              :batch_id 0
                                                                                                                                              :bunqto_expiry ""
                                                                                                                                              :bunqto_share_url ""
                                                                                                                                              :bunqto_status ""
                                                                                                                                              :bunqto_sub_status ""
                                                                                                                                              :bunqto_time_responded ""
                                                                                                                                              :counterparty_alias {}
                                                                                                                                              :created ""
                                                                                                                                              :description ""
                                                                                                                                              :geolocation {:altitude 0
                                                                                                                                                            :latitude 0
                                                                                                                                                            :longitude 0
                                                                                                                                                            :radius 0}
                                                                                                                                              :id 0
                                                                                                                                              :merchant_reference ""
                                                                                                                                              :monetary_account_id 0
                                                                                                                                              :payment_auto_allocate_instance {:created ""
                                                                                                                                                                               :error_message []
                                                                                                                                                                               :id 0
                                                                                                                                                                               :payment_auto_allocate_id 0
                                                                                                                                                                               :payment_batch {:payments {:Payment []}}
                                                                                                                                                                               :payment_id 0
                                                                                                                                                                               :status ""
                                                                                                                                                                               :updated ""}
                                                                                                                                              :request_reference_split_the_bill [{:id 0
                                                                                                                                                                                  :type ""}]
                                                                                                                                              :scheduled_id 0
                                                                                                                                              :sub_type ""
                                                                                                                                              :type ""
                                                                                                                                              :updated ""}]
                                                                                                                                  :reference ""
                                                                                                                                  :type ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"description\": \"\",\n  \"payments\": [\n    {\n      \"address_billing\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"address_shipping\": {},\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"balance_after_mutation\": {},\n      \"batch_id\": 0,\n      \"bunqto_expiry\": \"\",\n      \"bunqto_share_url\": \"\",\n      \"bunqto_status\": \"\",\n      \"bunqto_sub_status\": \"\",\n      \"bunqto_time_responded\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"geolocation\": {\n        \"altitude\": 0,\n        \"latitude\": 0,\n        \"longitude\": 0,\n        \"radius\": 0\n      },\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"monetary_account_id\": 0,\n      \"payment_auto_allocate_instance\": {\n        \"created\": \"\",\n        \"error_message\": [],\n        \"id\": 0,\n        \"payment_auto_allocate_id\": 0,\n        \"payment_batch\": {\n          \"payments\": {\n            \"Payment\": []\n          }\n        },\n        \"payment_id\": 0,\n        \"status\": \"\",\n        \"updated\": \"\"\n      },\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"scheduled_id\": 0,\n      \"sub_type\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"reference\": \"\",\n  \"type\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"description\": \"\",\n  \"payments\": [\n    {\n      \"address_billing\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"address_shipping\": {},\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"balance_after_mutation\": {},\n      \"batch_id\": 0,\n      \"bunqto_expiry\": \"\",\n      \"bunqto_share_url\": \"\",\n      \"bunqto_status\": \"\",\n      \"bunqto_sub_status\": \"\",\n      \"bunqto_time_responded\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"geolocation\": {\n        \"altitude\": 0,\n        \"latitude\": 0,\n        \"longitude\": 0,\n        \"radius\": 0\n      },\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"monetary_account_id\": 0,\n      \"payment_auto_allocate_instance\": {\n        \"created\": \"\",\n        \"error_message\": [],\n        \"id\": 0,\n        \"payment_auto_allocate_id\": 0,\n        \"payment_batch\": {\n          \"payments\": {\n            \"Payment\": []\n          }\n        },\n        \"payment_id\": 0,\n        \"status\": \"\",\n        \"updated\": \"\"\n      },\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"scheduled_id\": 0,\n      \"sub_type\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"reference\": \"\",\n  \"type\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"description\": \"\",\n  \"payments\": [\n    {\n      \"address_billing\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"address_shipping\": {},\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"balance_after_mutation\": {},\n      \"batch_id\": 0,\n      \"bunqto_expiry\": \"\",\n      \"bunqto_share_url\": \"\",\n      \"bunqto_status\": \"\",\n      \"bunqto_sub_status\": \"\",\n      \"bunqto_time_responded\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"geolocation\": {\n        \"altitude\": 0,\n        \"latitude\": 0,\n        \"longitude\": 0,\n        \"radius\": 0\n      },\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"monetary_account_id\": 0,\n      \"payment_auto_allocate_instance\": {\n        \"created\": \"\",\n        \"error_message\": [],\n        \"id\": 0,\n        \"payment_auto_allocate_id\": 0,\n        \"payment_batch\": {\n          \"payments\": {\n            \"Payment\": []\n          }\n        },\n        \"payment_id\": 0,\n        \"status\": \"\",\n        \"updated\": \"\"\n      },\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"scheduled_id\": 0,\n      \"sub_type\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"reference\": \"\",\n  \"type\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction"

	payload := strings.NewReader("{\n  \"description\": \"\",\n  \"payments\": [\n    {\n      \"address_billing\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"address_shipping\": {},\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"balance_after_mutation\": {},\n      \"batch_id\": 0,\n      \"bunqto_expiry\": \"\",\n      \"bunqto_share_url\": \"\",\n      \"bunqto_status\": \"\",\n      \"bunqto_sub_status\": \"\",\n      \"bunqto_time_responded\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"geolocation\": {\n        \"altitude\": 0,\n        \"latitude\": 0,\n        \"longitude\": 0,\n        \"radius\": 0\n      },\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"monetary_account_id\": 0,\n      \"payment_auto_allocate_instance\": {\n        \"created\": \"\",\n        \"error_message\": [],\n        \"id\": 0,\n        \"payment_auto_allocate_id\": 0,\n        \"payment_batch\": {\n          \"payments\": {\n            \"Payment\": []\n          }\n        },\n        \"payment_id\": 0,\n        \"status\": \"\",\n        \"updated\": \"\"\n      },\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"scheduled_id\": 0,\n      \"sub_type\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"reference\": \"\",\n  \"type\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/monetary-account/:monetary-accountID/translink-transaction HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 2519

{
  "description": "",
  "payments": [
    {
      "address_billing": {
        "city": "",
        "country": "",
        "extra": "",
        "house_number": "",
        "is_user_address_updated": false,
        "mailbox_name": "",
        "po_box": "",
        "postal_code": "",
        "province": "",
        "street": ""
      },
      "address_shipping": {},
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "allow_bunqto": false,
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "balance_after_mutation": {},
      "batch_id": 0,
      "bunqto_expiry": "",
      "bunqto_share_url": "",
      "bunqto_status": "",
      "bunqto_sub_status": "",
      "bunqto_time_responded": "",
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "geolocation": {
        "altitude": 0,
        "latitude": 0,
        "longitude": 0,
        "radius": 0
      },
      "id": 0,
      "merchant_reference": "",
      "monetary_account_id": 0,
      "payment_auto_allocate_instance": {
        "created": "",
        "error_message": [],
        "id": 0,
        "payment_auto_allocate_id": 0,
        "payment_batch": {
          "payments": {
            "Payment": []
          }
        },
        "payment_id": 0,
        "status": "",
        "updated": ""
      },
      "request_reference_split_the_bill": [
        {
          "id": 0,
          "type": ""
        }
      ],
      "scheduled_id": 0,
      "sub_type": "",
      "type": "",
      "updated": ""
    }
  ],
  "reference": "",
  "type": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"description\": \"\",\n  \"payments\": [\n    {\n      \"address_billing\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"address_shipping\": {},\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"balance_after_mutation\": {},\n      \"batch_id\": 0,\n      \"bunqto_expiry\": \"\",\n      \"bunqto_share_url\": \"\",\n      \"bunqto_status\": \"\",\n      \"bunqto_sub_status\": \"\",\n      \"bunqto_time_responded\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"geolocation\": {\n        \"altitude\": 0,\n        \"latitude\": 0,\n        \"longitude\": 0,\n        \"radius\": 0\n      },\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"monetary_account_id\": 0,\n      \"payment_auto_allocate_instance\": {\n        \"created\": \"\",\n        \"error_message\": [],\n        \"id\": 0,\n        \"payment_auto_allocate_id\": 0,\n        \"payment_batch\": {\n          \"payments\": {\n            \"Payment\": []\n          }\n        },\n        \"payment_id\": 0,\n        \"status\": \"\",\n        \"updated\": \"\"\n      },\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"scheduled_id\": 0,\n      \"sub_type\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"reference\": \"\",\n  \"type\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"description\": \"\",\n  \"payments\": [\n    {\n      \"address_billing\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"address_shipping\": {},\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"balance_after_mutation\": {},\n      \"batch_id\": 0,\n      \"bunqto_expiry\": \"\",\n      \"bunqto_share_url\": \"\",\n      \"bunqto_status\": \"\",\n      \"bunqto_sub_status\": \"\",\n      \"bunqto_time_responded\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"geolocation\": {\n        \"altitude\": 0,\n        \"latitude\": 0,\n        \"longitude\": 0,\n        \"radius\": 0\n      },\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"monetary_account_id\": 0,\n      \"payment_auto_allocate_instance\": {\n        \"created\": \"\",\n        \"error_message\": [],\n        \"id\": 0,\n        \"payment_auto_allocate_id\": 0,\n        \"payment_batch\": {\n          \"payments\": {\n            \"Payment\": []\n          }\n        },\n        \"payment_id\": 0,\n        \"status\": \"\",\n        \"updated\": \"\"\n      },\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"scheduled_id\": 0,\n      \"sub_type\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"reference\": \"\",\n  \"type\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"description\": \"\",\n  \"payments\": [\n    {\n      \"address_billing\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"address_shipping\": {},\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"balance_after_mutation\": {},\n      \"batch_id\": 0,\n      \"bunqto_expiry\": \"\",\n      \"bunqto_share_url\": \"\",\n      \"bunqto_status\": \"\",\n      \"bunqto_sub_status\": \"\",\n      \"bunqto_time_responded\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"geolocation\": {\n        \"altitude\": 0,\n        \"latitude\": 0,\n        \"longitude\": 0,\n        \"radius\": 0\n      },\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"monetary_account_id\": 0,\n      \"payment_auto_allocate_instance\": {\n        \"created\": \"\",\n        \"error_message\": [],\n        \"id\": 0,\n        \"payment_auto_allocate_id\": 0,\n        \"payment_batch\": {\n          \"payments\": {\n            \"Payment\": []\n          }\n        },\n        \"payment_id\": 0,\n        \"status\": \"\",\n        \"updated\": \"\"\n      },\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"scheduled_id\": 0,\n      \"sub_type\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"reference\": \"\",\n  \"type\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"description\": \"\",\n  \"payments\": [\n    {\n      \"address_billing\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"address_shipping\": {},\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"balance_after_mutation\": {},\n      \"batch_id\": 0,\n      \"bunqto_expiry\": \"\",\n      \"bunqto_share_url\": \"\",\n      \"bunqto_status\": \"\",\n      \"bunqto_sub_status\": \"\",\n      \"bunqto_time_responded\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"geolocation\": {\n        \"altitude\": 0,\n        \"latitude\": 0,\n        \"longitude\": 0,\n        \"radius\": 0\n      },\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"monetary_account_id\": 0,\n      \"payment_auto_allocate_instance\": {\n        \"created\": \"\",\n        \"error_message\": [],\n        \"id\": 0,\n        \"payment_auto_allocate_id\": 0,\n        \"payment_batch\": {\n          \"payments\": {\n            \"Payment\": []\n          }\n        },\n        \"payment_id\": 0,\n        \"status\": \"\",\n        \"updated\": \"\"\n      },\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"scheduled_id\": 0,\n      \"sub_type\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"reference\": \"\",\n  \"type\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  description: '',
  payments: [
    {
      address_billing: {
        city: '',
        country: '',
        extra: '',
        house_number: '',
        is_user_address_updated: false,
        mailbox_name: '',
        po_box: '',
        postal_code: '',
        province: '',
        street: ''
      },
      address_shipping: {},
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [
            {
              attachment_public_uuid: '',
              content_type: '',
              height: 0,
              width: 0
            }
          ],
          style: '',
          uuid: ''
        },
        bunq_me: {
          name: '',
          service: '',
          type: '',
          value: ''
        },
        country: '',
        display_name: '',
        iban: '',
        is_light: false,
        label_user: {
          avatar: {},
          country: '',
          display_name: '',
          public_nick_name: '',
          uuid: ''
        },
        merchant_category_code: '',
        swift_account_number: '',
        swift_bic: '',
        transferwise_account_number: '',
        transferwise_bank_code: ''
      },
      allow_bunqto: false,
      amount: {
        currency: '',
        value: ''
      },
      attachment: [
        {
          id: 0,
          monetary_account_id: 0
        }
      ],
      balance_after_mutation: {},
      batch_id: 0,
      bunqto_expiry: '',
      bunqto_share_url: '',
      bunqto_status: '',
      bunqto_sub_status: '',
      bunqto_time_responded: '',
      counterparty_alias: {},
      created: '',
      description: '',
      geolocation: {
        altitude: 0,
        latitude: 0,
        longitude: 0,
        radius: 0
      },
      id: 0,
      merchant_reference: '',
      monetary_account_id: 0,
      payment_auto_allocate_instance: {
        created: '',
        error_message: [],
        id: 0,
        payment_auto_allocate_id: 0,
        payment_batch: {
          payments: {
            Payment: []
          }
        },
        payment_id: 0,
        status: '',
        updated: ''
      },
      request_reference_split_the_bill: [
        {
          id: 0,
          type: ''
        }
      ],
      scheduled_id: 0,
      sub_type: '',
      type: '',
      updated: ''
    }
  ],
  reference: '',
  type: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    description: '',
    payments: [
      {
        address_billing: {
          city: '',
          country: '',
          extra: '',
          house_number: '',
          is_user_address_updated: false,
          mailbox_name: '',
          po_box: '',
          postal_code: '',
          province: '',
          street: ''
        },
        address_shipping: {},
        alias: {
          avatar: {
            anchor_uuid: '',
            image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
            style: '',
            uuid: ''
          },
          bunq_me: {name: '', service: '', type: '', value: ''},
          country: '',
          display_name: '',
          iban: '',
          is_light: false,
          label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
          merchant_category_code: '',
          swift_account_number: '',
          swift_bic: '',
          transferwise_account_number: '',
          transferwise_bank_code: ''
        },
        allow_bunqto: false,
        amount: {currency: '', value: ''},
        attachment: [{id: 0, monetary_account_id: 0}],
        balance_after_mutation: {},
        batch_id: 0,
        bunqto_expiry: '',
        bunqto_share_url: '',
        bunqto_status: '',
        bunqto_sub_status: '',
        bunqto_time_responded: '',
        counterparty_alias: {},
        created: '',
        description: '',
        geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
        id: 0,
        merchant_reference: '',
        monetary_account_id: 0,
        payment_auto_allocate_instance: {
          created: '',
          error_message: [],
          id: 0,
          payment_auto_allocate_id: 0,
          payment_batch: {payments: {Payment: []}},
          payment_id: 0,
          status: '',
          updated: ''
        },
        request_reference_split_the_bill: [{id: 0, type: ''}],
        scheduled_id: 0,
        sub_type: '',
        type: '',
        updated: ''
      }
    ],
    reference: '',
    type: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"description":"","payments":[{"address_billing":{"city":"","country":"","extra":"","house_number":"","is_user_address_updated":false,"mailbox_name":"","po_box":"","postal_code":"","province":"","street":""},"address_shipping":{},"alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"allow_bunqto":false,"amount":{"currency":"","value":""},"attachment":[{"id":0,"monetary_account_id":0}],"balance_after_mutation":{},"batch_id":0,"bunqto_expiry":"","bunqto_share_url":"","bunqto_status":"","bunqto_sub_status":"","bunqto_time_responded":"","counterparty_alias":{},"created":"","description":"","geolocation":{"altitude":0,"latitude":0,"longitude":0,"radius":0},"id":0,"merchant_reference":"","monetary_account_id":0,"payment_auto_allocate_instance":{"created":"","error_message":[],"id":0,"payment_auto_allocate_id":0,"payment_batch":{"payments":{"Payment":[]}},"payment_id":0,"status":"","updated":""},"request_reference_split_the_bill":[{"id":0,"type":""}],"scheduled_id":0,"sub_type":"","type":"","updated":""}],"reference":"","type":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "description": "",\n  "payments": [\n    {\n      "address_billing": {\n        "city": "",\n        "country": "",\n        "extra": "",\n        "house_number": "",\n        "is_user_address_updated": false,\n        "mailbox_name": "",\n        "po_box": "",\n        "postal_code": "",\n        "province": "",\n        "street": ""\n      },\n      "address_shipping": {},\n      "alias": {\n        "avatar": {\n          "anchor_uuid": "",\n          "image": [\n            {\n              "attachment_public_uuid": "",\n              "content_type": "",\n              "height": 0,\n              "width": 0\n            }\n          ],\n          "style": "",\n          "uuid": ""\n        },\n        "bunq_me": {\n          "name": "",\n          "service": "",\n          "type": "",\n          "value": ""\n        },\n        "country": "",\n        "display_name": "",\n        "iban": "",\n        "is_light": false,\n        "label_user": {\n          "avatar": {},\n          "country": "",\n          "display_name": "",\n          "public_nick_name": "",\n          "uuid": ""\n        },\n        "merchant_category_code": "",\n        "swift_account_number": "",\n        "swift_bic": "",\n        "transferwise_account_number": "",\n        "transferwise_bank_code": ""\n      },\n      "allow_bunqto": false,\n      "amount": {\n        "currency": "",\n        "value": ""\n      },\n      "attachment": [\n        {\n          "id": 0,\n          "monetary_account_id": 0\n        }\n      ],\n      "balance_after_mutation": {},\n      "batch_id": 0,\n      "bunqto_expiry": "",\n      "bunqto_share_url": "",\n      "bunqto_status": "",\n      "bunqto_sub_status": "",\n      "bunqto_time_responded": "",\n      "counterparty_alias": {},\n      "created": "",\n      "description": "",\n      "geolocation": {\n        "altitude": 0,\n        "latitude": 0,\n        "longitude": 0,\n        "radius": 0\n      },\n      "id": 0,\n      "merchant_reference": "",\n      "monetary_account_id": 0,\n      "payment_auto_allocate_instance": {\n        "created": "",\n        "error_message": [],\n        "id": 0,\n        "payment_auto_allocate_id": 0,\n        "payment_batch": {\n          "payments": {\n            "Payment": []\n          }\n        },\n        "payment_id": 0,\n        "status": "",\n        "updated": ""\n      },\n      "request_reference_split_the_bill": [\n        {\n          "id": 0,\n          "type": ""\n        }\n      ],\n      "scheduled_id": 0,\n      "sub_type": "",\n      "type": "",\n      "updated": ""\n    }\n  ],\n  "reference": "",\n  "type": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"description\": \"\",\n  \"payments\": [\n    {\n      \"address_billing\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"address_shipping\": {},\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"balance_after_mutation\": {},\n      \"batch_id\": 0,\n      \"bunqto_expiry\": \"\",\n      \"bunqto_share_url\": \"\",\n      \"bunqto_status\": \"\",\n      \"bunqto_sub_status\": \"\",\n      \"bunqto_time_responded\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"geolocation\": {\n        \"altitude\": 0,\n        \"latitude\": 0,\n        \"longitude\": 0,\n        \"radius\": 0\n      },\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"monetary_account_id\": 0,\n      \"payment_auto_allocate_instance\": {\n        \"created\": \"\",\n        \"error_message\": [],\n        \"id\": 0,\n        \"payment_auto_allocate_id\": 0,\n        \"payment_batch\": {\n          \"payments\": {\n            \"Payment\": []\n          }\n        },\n        \"payment_id\": 0,\n        \"status\": \"\",\n        \"updated\": \"\"\n      },\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"scheduled_id\": 0,\n      \"sub_type\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"reference\": \"\",\n  \"type\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/translink-transaction',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  description: '',
  payments: [
    {
      address_billing: {
        city: '',
        country: '',
        extra: '',
        house_number: '',
        is_user_address_updated: false,
        mailbox_name: '',
        po_box: '',
        postal_code: '',
        province: '',
        street: ''
      },
      address_shipping: {},
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
          style: '',
          uuid: ''
        },
        bunq_me: {name: '', service: '', type: '', value: ''},
        country: '',
        display_name: '',
        iban: '',
        is_light: false,
        label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
        merchant_category_code: '',
        swift_account_number: '',
        swift_bic: '',
        transferwise_account_number: '',
        transferwise_bank_code: ''
      },
      allow_bunqto: false,
      amount: {currency: '', value: ''},
      attachment: [{id: 0, monetary_account_id: 0}],
      balance_after_mutation: {},
      batch_id: 0,
      bunqto_expiry: '',
      bunqto_share_url: '',
      bunqto_status: '',
      bunqto_sub_status: '',
      bunqto_time_responded: '',
      counterparty_alias: {},
      created: '',
      description: '',
      geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
      id: 0,
      merchant_reference: '',
      monetary_account_id: 0,
      payment_auto_allocate_instance: {
        created: '',
        error_message: [],
        id: 0,
        payment_auto_allocate_id: 0,
        payment_batch: {payments: {Payment: []}},
        payment_id: 0,
        status: '',
        updated: ''
      },
      request_reference_split_the_bill: [{id: 0, type: ''}],
      scheduled_id: 0,
      sub_type: '',
      type: '',
      updated: ''
    }
  ],
  reference: '',
  type: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    description: '',
    payments: [
      {
        address_billing: {
          city: '',
          country: '',
          extra: '',
          house_number: '',
          is_user_address_updated: false,
          mailbox_name: '',
          po_box: '',
          postal_code: '',
          province: '',
          street: ''
        },
        address_shipping: {},
        alias: {
          avatar: {
            anchor_uuid: '',
            image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
            style: '',
            uuid: ''
          },
          bunq_me: {name: '', service: '', type: '', value: ''},
          country: '',
          display_name: '',
          iban: '',
          is_light: false,
          label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
          merchant_category_code: '',
          swift_account_number: '',
          swift_bic: '',
          transferwise_account_number: '',
          transferwise_bank_code: ''
        },
        allow_bunqto: false,
        amount: {currency: '', value: ''},
        attachment: [{id: 0, monetary_account_id: 0}],
        balance_after_mutation: {},
        batch_id: 0,
        bunqto_expiry: '',
        bunqto_share_url: '',
        bunqto_status: '',
        bunqto_sub_status: '',
        bunqto_time_responded: '',
        counterparty_alias: {},
        created: '',
        description: '',
        geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
        id: 0,
        merchant_reference: '',
        monetary_account_id: 0,
        payment_auto_allocate_instance: {
          created: '',
          error_message: [],
          id: 0,
          payment_auto_allocate_id: 0,
          payment_batch: {payments: {Payment: []}},
          payment_id: 0,
          status: '',
          updated: ''
        },
        request_reference_split_the_bill: [{id: 0, type: ''}],
        scheduled_id: 0,
        sub_type: '',
        type: '',
        updated: ''
      }
    ],
    reference: '',
    type: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  description: '',
  payments: [
    {
      address_billing: {
        city: '',
        country: '',
        extra: '',
        house_number: '',
        is_user_address_updated: false,
        mailbox_name: '',
        po_box: '',
        postal_code: '',
        province: '',
        street: ''
      },
      address_shipping: {},
      alias: {
        avatar: {
          anchor_uuid: '',
          image: [
            {
              attachment_public_uuid: '',
              content_type: '',
              height: 0,
              width: 0
            }
          ],
          style: '',
          uuid: ''
        },
        bunq_me: {
          name: '',
          service: '',
          type: '',
          value: ''
        },
        country: '',
        display_name: '',
        iban: '',
        is_light: false,
        label_user: {
          avatar: {},
          country: '',
          display_name: '',
          public_nick_name: '',
          uuid: ''
        },
        merchant_category_code: '',
        swift_account_number: '',
        swift_bic: '',
        transferwise_account_number: '',
        transferwise_bank_code: ''
      },
      allow_bunqto: false,
      amount: {
        currency: '',
        value: ''
      },
      attachment: [
        {
          id: 0,
          monetary_account_id: 0
        }
      ],
      balance_after_mutation: {},
      batch_id: 0,
      bunqto_expiry: '',
      bunqto_share_url: '',
      bunqto_status: '',
      bunqto_sub_status: '',
      bunqto_time_responded: '',
      counterparty_alias: {},
      created: '',
      description: '',
      geolocation: {
        altitude: 0,
        latitude: 0,
        longitude: 0,
        radius: 0
      },
      id: 0,
      merchant_reference: '',
      monetary_account_id: 0,
      payment_auto_allocate_instance: {
        created: '',
        error_message: [],
        id: 0,
        payment_auto_allocate_id: 0,
        payment_batch: {
          payments: {
            Payment: []
          }
        },
        payment_id: 0,
        status: '',
        updated: ''
      },
      request_reference_split_the_bill: [
        {
          id: 0,
          type: ''
        }
      ],
      scheduled_id: 0,
      sub_type: '',
      type: '',
      updated: ''
    }
  ],
  reference: '',
  type: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    description: '',
    payments: [
      {
        address_billing: {
          city: '',
          country: '',
          extra: '',
          house_number: '',
          is_user_address_updated: false,
          mailbox_name: '',
          po_box: '',
          postal_code: '',
          province: '',
          street: ''
        },
        address_shipping: {},
        alias: {
          avatar: {
            anchor_uuid: '',
            image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
            style: '',
            uuid: ''
          },
          bunq_me: {name: '', service: '', type: '', value: ''},
          country: '',
          display_name: '',
          iban: '',
          is_light: false,
          label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
          merchant_category_code: '',
          swift_account_number: '',
          swift_bic: '',
          transferwise_account_number: '',
          transferwise_bank_code: ''
        },
        allow_bunqto: false,
        amount: {currency: '', value: ''},
        attachment: [{id: 0, monetary_account_id: 0}],
        balance_after_mutation: {},
        batch_id: 0,
        bunqto_expiry: '',
        bunqto_share_url: '',
        bunqto_status: '',
        bunqto_sub_status: '',
        bunqto_time_responded: '',
        counterparty_alias: {},
        created: '',
        description: '',
        geolocation: {altitude: 0, latitude: 0, longitude: 0, radius: 0},
        id: 0,
        merchant_reference: '',
        monetary_account_id: 0,
        payment_auto_allocate_instance: {
          created: '',
          error_message: [],
          id: 0,
          payment_auto_allocate_id: 0,
          payment_batch: {payments: {Payment: []}},
          payment_id: 0,
          status: '',
          updated: ''
        },
        request_reference_split_the_bill: [{id: 0, type: ''}],
        scheduled_id: 0,
        sub_type: '',
        type: '',
        updated: ''
      }
    ],
    reference: '',
    type: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"description":"","payments":[{"address_billing":{"city":"","country":"","extra":"","house_number":"","is_user_address_updated":false,"mailbox_name":"","po_box":"","postal_code":"","province":"","street":""},"address_shipping":{},"alias":{"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"bunq_me":{"name":"","service":"","type":"","value":""},"country":"","display_name":"","iban":"","is_light":false,"label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"merchant_category_code":"","swift_account_number":"","swift_bic":"","transferwise_account_number":"","transferwise_bank_code":""},"allow_bunqto":false,"amount":{"currency":"","value":""},"attachment":[{"id":0,"monetary_account_id":0}],"balance_after_mutation":{},"batch_id":0,"bunqto_expiry":"","bunqto_share_url":"","bunqto_status":"","bunqto_sub_status":"","bunqto_time_responded":"","counterparty_alias":{},"created":"","description":"","geolocation":{"altitude":0,"latitude":0,"longitude":0,"radius":0},"id":0,"merchant_reference":"","monetary_account_id":0,"payment_auto_allocate_instance":{"created":"","error_message":[],"id":0,"payment_auto_allocate_id":0,"payment_batch":{"payments":{"Payment":[]}},"payment_id":0,"status":"","updated":""},"request_reference_split_the_bill":[{"id":0,"type":""}],"scheduled_id":0,"sub_type":"","type":"","updated":""}],"reference":"","type":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"description": @"",
                              @"payments": @[ @{ @"address_billing": @{ @"city": @"", @"country": @"", @"extra": @"", @"house_number": @"", @"is_user_address_updated": @NO, @"mailbox_name": @"", @"po_box": @"", @"postal_code": @"", @"province": @"", @"street": @"" }, @"address_shipping": @{  }, @"alias": @{ @"avatar": @{ @"anchor_uuid": @"", @"image": @[ @{ @"attachment_public_uuid": @"", @"content_type": @"", @"height": @0, @"width": @0 } ], @"style": @"", @"uuid": @"" }, @"bunq_me": @{ @"name": @"", @"service": @"", @"type": @"", @"value": @"" }, @"country": @"", @"display_name": @"", @"iban": @"", @"is_light": @NO, @"label_user": @{ @"avatar": @{  }, @"country": @"", @"display_name": @"", @"public_nick_name": @"", @"uuid": @"" }, @"merchant_category_code": @"", @"swift_account_number": @"", @"swift_bic": @"", @"transferwise_account_number": @"", @"transferwise_bank_code": @"" }, @"allow_bunqto": @NO, @"amount": @{ @"currency": @"", @"value": @"" }, @"attachment": @[ @{ @"id": @0, @"monetary_account_id": @0 } ], @"balance_after_mutation": @{  }, @"batch_id": @0, @"bunqto_expiry": @"", @"bunqto_share_url": @"", @"bunqto_status": @"", @"bunqto_sub_status": @"", @"bunqto_time_responded": @"", @"counterparty_alias": @{  }, @"created": @"", @"description": @"", @"geolocation": @{ @"altitude": @0, @"latitude": @0, @"longitude": @0, @"radius": @0 }, @"id": @0, @"merchant_reference": @"", @"monetary_account_id": @0, @"payment_auto_allocate_instance": @{ @"created": @"", @"error_message": @[  ], @"id": @0, @"payment_auto_allocate_id": @0, @"payment_batch": @{ @"payments": @{ @"Payment": @[  ] } }, @"payment_id": @0, @"status": @"", @"updated": @"" }, @"request_reference_split_the_bill": @[ @{ @"id": @0, @"type": @"" } ], @"scheduled_id": @0, @"sub_type": @"", @"type": @"", @"updated": @"" } ],
                              @"reference": @"",
                              @"type": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"description\": \"\",\n  \"payments\": [\n    {\n      \"address_billing\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"address_shipping\": {},\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"balance_after_mutation\": {},\n      \"batch_id\": 0,\n      \"bunqto_expiry\": \"\",\n      \"bunqto_share_url\": \"\",\n      \"bunqto_status\": \"\",\n      \"bunqto_sub_status\": \"\",\n      \"bunqto_time_responded\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"geolocation\": {\n        \"altitude\": 0,\n        \"latitude\": 0,\n        \"longitude\": 0,\n        \"radius\": 0\n      },\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"monetary_account_id\": 0,\n      \"payment_auto_allocate_instance\": {\n        \"created\": \"\",\n        \"error_message\": [],\n        \"id\": 0,\n        \"payment_auto_allocate_id\": 0,\n        \"payment_batch\": {\n          \"payments\": {\n            \"Payment\": []\n          }\n        },\n        \"payment_id\": 0,\n        \"status\": \"\",\n        \"updated\": \"\"\n      },\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"scheduled_id\": 0,\n      \"sub_type\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"reference\": \"\",\n  \"type\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'description' => '',
    'payments' => [
        [
                'address_billing' => [
                                'city' => '',
                                'country' => '',
                                'extra' => '',
                                'house_number' => '',
                                'is_user_address_updated' => null,
                                'mailbox_name' => '',
                                'po_box' => '',
                                'postal_code' => '',
                                'province' => '',
                                'street' => ''
                ],
                'address_shipping' => [
                                
                ],
                'alias' => [
                                'avatar' => [
                                                                'anchor_uuid' => '',
                                                                'image' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'attachment_public_uuid' => '',
                                                                                                                                                                                                                                                                'content_type' => '',
                                                                                                                                                                                                                                                                'height' => 0,
                                                                                                                                                                                                                                                                'width' => 0
                                                                                                                                ]
                                                                ],
                                                                'style' => '',
                                                                'uuid' => ''
                                ],
                                'bunq_me' => [
                                                                'name' => '',
                                                                'service' => '',
                                                                'type' => '',
                                                                'value' => ''
                                ],
                                'country' => '',
                                'display_name' => '',
                                'iban' => '',
                                'is_light' => null,
                                'label_user' => [
                                                                'avatar' => [
                                                                                                                                
                                                                ],
                                                                'country' => '',
                                                                'display_name' => '',
                                                                'public_nick_name' => '',
                                                                'uuid' => ''
                                ],
                                'merchant_category_code' => '',
                                'swift_account_number' => '',
                                'swift_bic' => '',
                                'transferwise_account_number' => '',
                                'transferwise_bank_code' => ''
                ],
                'allow_bunqto' => null,
                'amount' => [
                                'currency' => '',
                                'value' => ''
                ],
                'attachment' => [
                                [
                                                                'id' => 0,
                                                                'monetary_account_id' => 0
                                ]
                ],
                'balance_after_mutation' => [
                                
                ],
                'batch_id' => 0,
                'bunqto_expiry' => '',
                'bunqto_share_url' => '',
                'bunqto_status' => '',
                'bunqto_sub_status' => '',
                'bunqto_time_responded' => '',
                'counterparty_alias' => [
                                
                ],
                'created' => '',
                'description' => '',
                'geolocation' => [
                                'altitude' => 0,
                                'latitude' => 0,
                                'longitude' => 0,
                                'radius' => 0
                ],
                'id' => 0,
                'merchant_reference' => '',
                'monetary_account_id' => 0,
                'payment_auto_allocate_instance' => [
                                'created' => '',
                                'error_message' => [
                                                                
                                ],
                                'id' => 0,
                                'payment_auto_allocate_id' => 0,
                                'payment_batch' => [
                                                                'payments' => [
                                                                                                                                'Payment' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'payment_id' => 0,
                                'status' => '',
                                'updated' => ''
                ],
                'request_reference_split_the_bill' => [
                                [
                                                                'id' => 0,
                                                                'type' => ''
                                ]
                ],
                'scheduled_id' => 0,
                'sub_type' => '',
                'type' => '',
                'updated' => ''
        ]
    ],
    'reference' => '',
    'type' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction', [
  'body' => '{
  "description": "",
  "payments": [
    {
      "address_billing": {
        "city": "",
        "country": "",
        "extra": "",
        "house_number": "",
        "is_user_address_updated": false,
        "mailbox_name": "",
        "po_box": "",
        "postal_code": "",
        "province": "",
        "street": ""
      },
      "address_shipping": {},
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "allow_bunqto": false,
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "balance_after_mutation": {},
      "batch_id": 0,
      "bunqto_expiry": "",
      "bunqto_share_url": "",
      "bunqto_status": "",
      "bunqto_sub_status": "",
      "bunqto_time_responded": "",
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "geolocation": {
        "altitude": 0,
        "latitude": 0,
        "longitude": 0,
        "radius": 0
      },
      "id": 0,
      "merchant_reference": "",
      "monetary_account_id": 0,
      "payment_auto_allocate_instance": {
        "created": "",
        "error_message": [],
        "id": 0,
        "payment_auto_allocate_id": 0,
        "payment_batch": {
          "payments": {
            "Payment": []
          }
        },
        "payment_id": 0,
        "status": "",
        "updated": ""
      },
      "request_reference_split_the_bill": [
        {
          "id": 0,
          "type": ""
        }
      ],
      "scheduled_id": 0,
      "sub_type": "",
      "type": "",
      "updated": ""
    }
  ],
  "reference": "",
  "type": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'description' => '',
  'payments' => [
    [
        'address_billing' => [
                'city' => '',
                'country' => '',
                'extra' => '',
                'house_number' => '',
                'is_user_address_updated' => null,
                'mailbox_name' => '',
                'po_box' => '',
                'postal_code' => '',
                'province' => '',
                'street' => ''
        ],
        'address_shipping' => [
                
        ],
        'alias' => [
                'avatar' => [
                                'anchor_uuid' => '',
                                'image' => [
                                                                [
                                                                                                                                'attachment_public_uuid' => '',
                                                                                                                                'content_type' => '',
                                                                                                                                'height' => 0,
                                                                                                                                'width' => 0
                                                                ]
                                ],
                                'style' => '',
                                'uuid' => ''
                ],
                'bunq_me' => [
                                'name' => '',
                                'service' => '',
                                'type' => '',
                                'value' => ''
                ],
                'country' => '',
                'display_name' => '',
                'iban' => '',
                'is_light' => null,
                'label_user' => [
                                'avatar' => [
                                                                
                                ],
                                'country' => '',
                                'display_name' => '',
                                'public_nick_name' => '',
                                'uuid' => ''
                ],
                'merchant_category_code' => '',
                'swift_account_number' => '',
                'swift_bic' => '',
                'transferwise_account_number' => '',
                'transferwise_bank_code' => ''
        ],
        'allow_bunqto' => null,
        'amount' => [
                'currency' => '',
                'value' => ''
        ],
        'attachment' => [
                [
                                'id' => 0,
                                'monetary_account_id' => 0
                ]
        ],
        'balance_after_mutation' => [
                
        ],
        'batch_id' => 0,
        'bunqto_expiry' => '',
        'bunqto_share_url' => '',
        'bunqto_status' => '',
        'bunqto_sub_status' => '',
        'bunqto_time_responded' => '',
        'counterparty_alias' => [
                
        ],
        'created' => '',
        'description' => '',
        'geolocation' => [
                'altitude' => 0,
                'latitude' => 0,
                'longitude' => 0,
                'radius' => 0
        ],
        'id' => 0,
        'merchant_reference' => '',
        'monetary_account_id' => 0,
        'payment_auto_allocate_instance' => [
                'created' => '',
                'error_message' => [
                                
                ],
                'id' => 0,
                'payment_auto_allocate_id' => 0,
                'payment_batch' => [
                                'payments' => [
                                                                'Payment' => [
                                                                                                                                
                                                                ]
                                ]
                ],
                'payment_id' => 0,
                'status' => '',
                'updated' => ''
        ],
        'request_reference_split_the_bill' => [
                [
                                'id' => 0,
                                'type' => ''
                ]
        ],
        'scheduled_id' => 0,
        'sub_type' => '',
        'type' => '',
        'updated' => ''
    ]
  ],
  'reference' => '',
  'type' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'description' => '',
  'payments' => [
    [
        'address_billing' => [
                'city' => '',
                'country' => '',
                'extra' => '',
                'house_number' => '',
                'is_user_address_updated' => null,
                'mailbox_name' => '',
                'po_box' => '',
                'postal_code' => '',
                'province' => '',
                'street' => ''
        ],
        'address_shipping' => [
                
        ],
        'alias' => [
                'avatar' => [
                                'anchor_uuid' => '',
                                'image' => [
                                                                [
                                                                                                                                'attachment_public_uuid' => '',
                                                                                                                                'content_type' => '',
                                                                                                                                'height' => 0,
                                                                                                                                'width' => 0
                                                                ]
                                ],
                                'style' => '',
                                'uuid' => ''
                ],
                'bunq_me' => [
                                'name' => '',
                                'service' => '',
                                'type' => '',
                                'value' => ''
                ],
                'country' => '',
                'display_name' => '',
                'iban' => '',
                'is_light' => null,
                'label_user' => [
                                'avatar' => [
                                                                
                                ],
                                'country' => '',
                                'display_name' => '',
                                'public_nick_name' => '',
                                'uuid' => ''
                ],
                'merchant_category_code' => '',
                'swift_account_number' => '',
                'swift_bic' => '',
                'transferwise_account_number' => '',
                'transferwise_bank_code' => ''
        ],
        'allow_bunqto' => null,
        'amount' => [
                'currency' => '',
                'value' => ''
        ],
        'attachment' => [
                [
                                'id' => 0,
                                'monetary_account_id' => 0
                ]
        ],
        'balance_after_mutation' => [
                
        ],
        'batch_id' => 0,
        'bunqto_expiry' => '',
        'bunqto_share_url' => '',
        'bunqto_status' => '',
        'bunqto_sub_status' => '',
        'bunqto_time_responded' => '',
        'counterparty_alias' => [
                
        ],
        'created' => '',
        'description' => '',
        'geolocation' => [
                'altitude' => 0,
                'latitude' => 0,
                'longitude' => 0,
                'radius' => 0
        ],
        'id' => 0,
        'merchant_reference' => '',
        'monetary_account_id' => 0,
        'payment_auto_allocate_instance' => [
                'created' => '',
                'error_message' => [
                                
                ],
                'id' => 0,
                'payment_auto_allocate_id' => 0,
                'payment_batch' => [
                                'payments' => [
                                                                'Payment' => [
                                                                                                                                
                                                                ]
                                ]
                ],
                'payment_id' => 0,
                'status' => '',
                'updated' => ''
        ],
        'request_reference_split_the_bill' => [
                [
                                'id' => 0,
                                'type' => ''
                ]
        ],
        'scheduled_id' => 0,
        'sub_type' => '',
        'type' => '',
        'updated' => ''
    ]
  ],
  'reference' => '',
  'type' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "description": "",
  "payments": [
    {
      "address_billing": {
        "city": "",
        "country": "",
        "extra": "",
        "house_number": "",
        "is_user_address_updated": false,
        "mailbox_name": "",
        "po_box": "",
        "postal_code": "",
        "province": "",
        "street": ""
      },
      "address_shipping": {},
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "allow_bunqto": false,
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "balance_after_mutation": {},
      "batch_id": 0,
      "bunqto_expiry": "",
      "bunqto_share_url": "",
      "bunqto_status": "",
      "bunqto_sub_status": "",
      "bunqto_time_responded": "",
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "geolocation": {
        "altitude": 0,
        "latitude": 0,
        "longitude": 0,
        "radius": 0
      },
      "id": 0,
      "merchant_reference": "",
      "monetary_account_id": 0,
      "payment_auto_allocate_instance": {
        "created": "",
        "error_message": [],
        "id": 0,
        "payment_auto_allocate_id": 0,
        "payment_batch": {
          "payments": {
            "Payment": []
          }
        },
        "payment_id": 0,
        "status": "",
        "updated": ""
      },
      "request_reference_split_the_bill": [
        {
          "id": 0,
          "type": ""
        }
      ],
      "scheduled_id": 0,
      "sub_type": "",
      "type": "",
      "updated": ""
    }
  ],
  "reference": "",
  "type": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "description": "",
  "payments": [
    {
      "address_billing": {
        "city": "",
        "country": "",
        "extra": "",
        "house_number": "",
        "is_user_address_updated": false,
        "mailbox_name": "",
        "po_box": "",
        "postal_code": "",
        "province": "",
        "street": ""
      },
      "address_shipping": {},
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "allow_bunqto": false,
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "balance_after_mutation": {},
      "batch_id": 0,
      "bunqto_expiry": "",
      "bunqto_share_url": "",
      "bunqto_status": "",
      "bunqto_sub_status": "",
      "bunqto_time_responded": "",
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "geolocation": {
        "altitude": 0,
        "latitude": 0,
        "longitude": 0,
        "radius": 0
      },
      "id": 0,
      "merchant_reference": "",
      "monetary_account_id": 0,
      "payment_auto_allocate_instance": {
        "created": "",
        "error_message": [],
        "id": 0,
        "payment_auto_allocate_id": 0,
        "payment_batch": {
          "payments": {
            "Payment": []
          }
        },
        "payment_id": 0,
        "status": "",
        "updated": ""
      },
      "request_reference_split_the_bill": [
        {
          "id": 0,
          "type": ""
        }
      ],
      "scheduled_id": 0,
      "sub_type": "",
      "type": "",
      "updated": ""
    }
  ],
  "reference": "",
  "type": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"description\": \"\",\n  \"payments\": [\n    {\n      \"address_billing\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"address_shipping\": {},\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"balance_after_mutation\": {},\n      \"batch_id\": 0,\n      \"bunqto_expiry\": \"\",\n      \"bunqto_share_url\": \"\",\n      \"bunqto_status\": \"\",\n      \"bunqto_sub_status\": \"\",\n      \"bunqto_time_responded\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"geolocation\": {\n        \"altitude\": 0,\n        \"latitude\": 0,\n        \"longitude\": 0,\n        \"radius\": 0\n      },\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"monetary_account_id\": 0,\n      \"payment_auto_allocate_instance\": {\n        \"created\": \"\",\n        \"error_message\": [],\n        \"id\": 0,\n        \"payment_auto_allocate_id\": 0,\n        \"payment_batch\": {\n          \"payments\": {\n            \"Payment\": []\n          }\n        },\n        \"payment_id\": 0,\n        \"status\": \"\",\n        \"updated\": \"\"\n      },\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"scheduled_id\": 0,\n      \"sub_type\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"reference\": \"\",\n  \"type\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/translink-transaction", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction"

payload = {
    "description": "",
    "payments": [
        {
            "address_billing": {
                "city": "",
                "country": "",
                "extra": "",
                "house_number": "",
                "is_user_address_updated": False,
                "mailbox_name": "",
                "po_box": "",
                "postal_code": "",
                "province": "",
                "street": ""
            },
            "address_shipping": {},
            "alias": {
                "avatar": {
                    "anchor_uuid": "",
                    "image": [
                        {
                            "attachment_public_uuid": "",
                            "content_type": "",
                            "height": 0,
                            "width": 0
                        }
                    ],
                    "style": "",
                    "uuid": ""
                },
                "bunq_me": {
                    "name": "",
                    "service": "",
                    "type": "",
                    "value": ""
                },
                "country": "",
                "display_name": "",
                "iban": "",
                "is_light": False,
                "label_user": {
                    "avatar": {},
                    "country": "",
                    "display_name": "",
                    "public_nick_name": "",
                    "uuid": ""
                },
                "merchant_category_code": "",
                "swift_account_number": "",
                "swift_bic": "",
                "transferwise_account_number": "",
                "transferwise_bank_code": ""
            },
            "allow_bunqto": False,
            "amount": {
                "currency": "",
                "value": ""
            },
            "attachment": [
                {
                    "id": 0,
                    "monetary_account_id": 0
                }
            ],
            "balance_after_mutation": {},
            "batch_id": 0,
            "bunqto_expiry": "",
            "bunqto_share_url": "",
            "bunqto_status": "",
            "bunqto_sub_status": "",
            "bunqto_time_responded": "",
            "counterparty_alias": {},
            "created": "",
            "description": "",
            "geolocation": {
                "altitude": 0,
                "latitude": 0,
                "longitude": 0,
                "radius": 0
            },
            "id": 0,
            "merchant_reference": "",
            "monetary_account_id": 0,
            "payment_auto_allocate_instance": {
                "created": "",
                "error_message": [],
                "id": 0,
                "payment_auto_allocate_id": 0,
                "payment_batch": { "payments": { "Payment": [] } },
                "payment_id": 0,
                "status": "",
                "updated": ""
            },
            "request_reference_split_the_bill": [
                {
                    "id": 0,
                    "type": ""
                }
            ],
            "scheduled_id": 0,
            "sub_type": "",
            "type": "",
            "updated": ""
        }
    ],
    "reference": "",
    "type": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction"

payload <- "{\n  \"description\": \"\",\n  \"payments\": [\n    {\n      \"address_billing\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"address_shipping\": {},\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"balance_after_mutation\": {},\n      \"batch_id\": 0,\n      \"bunqto_expiry\": \"\",\n      \"bunqto_share_url\": \"\",\n      \"bunqto_status\": \"\",\n      \"bunqto_sub_status\": \"\",\n      \"bunqto_time_responded\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"geolocation\": {\n        \"altitude\": 0,\n        \"latitude\": 0,\n        \"longitude\": 0,\n        \"radius\": 0\n      },\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"monetary_account_id\": 0,\n      \"payment_auto_allocate_instance\": {\n        \"created\": \"\",\n        \"error_message\": [],\n        \"id\": 0,\n        \"payment_auto_allocate_id\": 0,\n        \"payment_batch\": {\n          \"payments\": {\n            \"Payment\": []\n          }\n        },\n        \"payment_id\": 0,\n        \"status\": \"\",\n        \"updated\": \"\"\n      },\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"scheduled_id\": 0,\n      \"sub_type\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"reference\": \"\",\n  \"type\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"description\": \"\",\n  \"payments\": [\n    {\n      \"address_billing\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"address_shipping\": {},\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"balance_after_mutation\": {},\n      \"batch_id\": 0,\n      \"bunqto_expiry\": \"\",\n      \"bunqto_share_url\": \"\",\n      \"bunqto_status\": \"\",\n      \"bunqto_sub_status\": \"\",\n      \"bunqto_time_responded\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"geolocation\": {\n        \"altitude\": 0,\n        \"latitude\": 0,\n        \"longitude\": 0,\n        \"radius\": 0\n      },\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"monetary_account_id\": 0,\n      \"payment_auto_allocate_instance\": {\n        \"created\": \"\",\n        \"error_message\": [],\n        \"id\": 0,\n        \"payment_auto_allocate_id\": 0,\n        \"payment_batch\": {\n          \"payments\": {\n            \"Payment\": []\n          }\n        },\n        \"payment_id\": 0,\n        \"status\": \"\",\n        \"updated\": \"\"\n      },\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"scheduled_id\": 0,\n      \"sub_type\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"reference\": \"\",\n  \"type\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/monetary-account/:monetary-accountID/translink-transaction') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"description\": \"\",\n  \"payments\": [\n    {\n      \"address_billing\": {\n        \"city\": \"\",\n        \"country\": \"\",\n        \"extra\": \"\",\n        \"house_number\": \"\",\n        \"is_user_address_updated\": false,\n        \"mailbox_name\": \"\",\n        \"po_box\": \"\",\n        \"postal_code\": \"\",\n        \"province\": \"\",\n        \"street\": \"\"\n      },\n      \"address_shipping\": {},\n      \"alias\": {\n        \"avatar\": {\n          \"anchor_uuid\": \"\",\n          \"image\": [\n            {\n              \"attachment_public_uuid\": \"\",\n              \"content_type\": \"\",\n              \"height\": 0,\n              \"width\": 0\n            }\n          ],\n          \"style\": \"\",\n          \"uuid\": \"\"\n        },\n        \"bunq_me\": {\n          \"name\": \"\",\n          \"service\": \"\",\n          \"type\": \"\",\n          \"value\": \"\"\n        },\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"iban\": \"\",\n        \"is_light\": false,\n        \"label_user\": {\n          \"avatar\": {},\n          \"country\": \"\",\n          \"display_name\": \"\",\n          \"public_nick_name\": \"\",\n          \"uuid\": \"\"\n        },\n        \"merchant_category_code\": \"\",\n        \"swift_account_number\": \"\",\n        \"swift_bic\": \"\",\n        \"transferwise_account_number\": \"\",\n        \"transferwise_bank_code\": \"\"\n      },\n      \"allow_bunqto\": false,\n      \"amount\": {\n        \"currency\": \"\",\n        \"value\": \"\"\n      },\n      \"attachment\": [\n        {\n          \"id\": 0,\n          \"monetary_account_id\": 0\n        }\n      ],\n      \"balance_after_mutation\": {},\n      \"batch_id\": 0,\n      \"bunqto_expiry\": \"\",\n      \"bunqto_share_url\": \"\",\n      \"bunqto_status\": \"\",\n      \"bunqto_sub_status\": \"\",\n      \"bunqto_time_responded\": \"\",\n      \"counterparty_alias\": {},\n      \"created\": \"\",\n      \"description\": \"\",\n      \"geolocation\": {\n        \"altitude\": 0,\n        \"latitude\": 0,\n        \"longitude\": 0,\n        \"radius\": 0\n      },\n      \"id\": 0,\n      \"merchant_reference\": \"\",\n      \"monetary_account_id\": 0,\n      \"payment_auto_allocate_instance\": {\n        \"created\": \"\",\n        \"error_message\": [],\n        \"id\": 0,\n        \"payment_auto_allocate_id\": 0,\n        \"payment_batch\": {\n          \"payments\": {\n            \"Payment\": []\n          }\n        },\n        \"payment_id\": 0,\n        \"status\": \"\",\n        \"updated\": \"\"\n      },\n      \"request_reference_split_the_bill\": [\n        {\n          \"id\": 0,\n          \"type\": \"\"\n        }\n      ],\n      \"scheduled_id\": 0,\n      \"sub_type\": \"\",\n      \"type\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"reference\": \"\",\n  \"type\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction";

    let payload = json!({
        "description": "",
        "payments": (
            json!({
                "address_billing": json!({
                    "city": "",
                    "country": "",
                    "extra": "",
                    "house_number": "",
                    "is_user_address_updated": false,
                    "mailbox_name": "",
                    "po_box": "",
                    "postal_code": "",
                    "province": "",
                    "street": ""
                }),
                "address_shipping": json!({}),
                "alias": json!({
                    "avatar": json!({
                        "anchor_uuid": "",
                        "image": (
                            json!({
                                "attachment_public_uuid": "",
                                "content_type": "",
                                "height": 0,
                                "width": 0
                            })
                        ),
                        "style": "",
                        "uuid": ""
                    }),
                    "bunq_me": json!({
                        "name": "",
                        "service": "",
                        "type": "",
                        "value": ""
                    }),
                    "country": "",
                    "display_name": "",
                    "iban": "",
                    "is_light": false,
                    "label_user": json!({
                        "avatar": json!({}),
                        "country": "",
                        "display_name": "",
                        "public_nick_name": "",
                        "uuid": ""
                    }),
                    "merchant_category_code": "",
                    "swift_account_number": "",
                    "swift_bic": "",
                    "transferwise_account_number": "",
                    "transferwise_bank_code": ""
                }),
                "allow_bunqto": false,
                "amount": json!({
                    "currency": "",
                    "value": ""
                }),
                "attachment": (
                    json!({
                        "id": 0,
                        "monetary_account_id": 0
                    })
                ),
                "balance_after_mutation": json!({}),
                "batch_id": 0,
                "bunqto_expiry": "",
                "bunqto_share_url": "",
                "bunqto_status": "",
                "bunqto_sub_status": "",
                "bunqto_time_responded": "",
                "counterparty_alias": json!({}),
                "created": "",
                "description": "",
                "geolocation": json!({
                    "altitude": 0,
                    "latitude": 0,
                    "longitude": 0,
                    "radius": 0
                }),
                "id": 0,
                "merchant_reference": "",
                "monetary_account_id": 0,
                "payment_auto_allocate_instance": json!({
                    "created": "",
                    "error_message": (),
                    "id": 0,
                    "payment_auto_allocate_id": 0,
                    "payment_batch": json!({"payments": json!({"Payment": ()})}),
                    "payment_id": 0,
                    "status": "",
                    "updated": ""
                }),
                "request_reference_split_the_bill": (
                    json!({
                        "id": 0,
                        "type": ""
                    })
                ),
                "scheduled_id": 0,
                "sub_type": "",
                "type": "",
                "updated": ""
            })
        ),
        "reference": "",
        "type": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "description": "",
  "payments": [
    {
      "address_billing": {
        "city": "",
        "country": "",
        "extra": "",
        "house_number": "",
        "is_user_address_updated": false,
        "mailbox_name": "",
        "po_box": "",
        "postal_code": "",
        "province": "",
        "street": ""
      },
      "address_shipping": {},
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "allow_bunqto": false,
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "balance_after_mutation": {},
      "batch_id": 0,
      "bunqto_expiry": "",
      "bunqto_share_url": "",
      "bunqto_status": "",
      "bunqto_sub_status": "",
      "bunqto_time_responded": "",
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "geolocation": {
        "altitude": 0,
        "latitude": 0,
        "longitude": 0,
        "radius": 0
      },
      "id": 0,
      "merchant_reference": "",
      "monetary_account_id": 0,
      "payment_auto_allocate_instance": {
        "created": "",
        "error_message": [],
        "id": 0,
        "payment_auto_allocate_id": 0,
        "payment_batch": {
          "payments": {
            "Payment": []
          }
        },
        "payment_id": 0,
        "status": "",
        "updated": ""
      },
      "request_reference_split_the_bill": [
        {
          "id": 0,
          "type": ""
        }
      ],
      "scheduled_id": 0,
      "sub_type": "",
      "type": "",
      "updated": ""
    }
  ],
  "reference": "",
  "type": ""
}'
echo '{
  "description": "",
  "payments": [
    {
      "address_billing": {
        "city": "",
        "country": "",
        "extra": "",
        "house_number": "",
        "is_user_address_updated": false,
        "mailbox_name": "",
        "po_box": "",
        "postal_code": "",
        "province": "",
        "street": ""
      },
      "address_shipping": {},
      "alias": {
        "avatar": {
          "anchor_uuid": "",
          "image": [
            {
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            }
          ],
          "style": "",
          "uuid": ""
        },
        "bunq_me": {
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        },
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": {
          "avatar": {},
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        },
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      },
      "allow_bunqto": false,
      "amount": {
        "currency": "",
        "value": ""
      },
      "attachment": [
        {
          "id": 0,
          "monetary_account_id": 0
        }
      ],
      "balance_after_mutation": {},
      "batch_id": 0,
      "bunqto_expiry": "",
      "bunqto_share_url": "",
      "bunqto_status": "",
      "bunqto_sub_status": "",
      "bunqto_time_responded": "",
      "counterparty_alias": {},
      "created": "",
      "description": "",
      "geolocation": {
        "altitude": 0,
        "latitude": 0,
        "longitude": 0,
        "radius": 0
      },
      "id": 0,
      "merchant_reference": "",
      "monetary_account_id": 0,
      "payment_auto_allocate_instance": {
        "created": "",
        "error_message": [],
        "id": 0,
        "payment_auto_allocate_id": 0,
        "payment_batch": {
          "payments": {
            "Payment": []
          }
        },
        "payment_id": 0,
        "status": "",
        "updated": ""
      },
      "request_reference_split_the_bill": [
        {
          "id": 0,
          "type": ""
        }
      ],
      "scheduled_id": 0,
      "sub_type": "",
      "type": "",
      "updated": ""
    }
  ],
  "reference": "",
  "type": ""
}' |  \
  http POST {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "description": "",\n  "payments": [\n    {\n      "address_billing": {\n        "city": "",\n        "country": "",\n        "extra": "",\n        "house_number": "",\n        "is_user_address_updated": false,\n        "mailbox_name": "",\n        "po_box": "",\n        "postal_code": "",\n        "province": "",\n        "street": ""\n      },\n      "address_shipping": {},\n      "alias": {\n        "avatar": {\n          "anchor_uuid": "",\n          "image": [\n            {\n              "attachment_public_uuid": "",\n              "content_type": "",\n              "height": 0,\n              "width": 0\n            }\n          ],\n          "style": "",\n          "uuid": ""\n        },\n        "bunq_me": {\n          "name": "",\n          "service": "",\n          "type": "",\n          "value": ""\n        },\n        "country": "",\n        "display_name": "",\n        "iban": "",\n        "is_light": false,\n        "label_user": {\n          "avatar": {},\n          "country": "",\n          "display_name": "",\n          "public_nick_name": "",\n          "uuid": ""\n        },\n        "merchant_category_code": "",\n        "swift_account_number": "",\n        "swift_bic": "",\n        "transferwise_account_number": "",\n        "transferwise_bank_code": ""\n      },\n      "allow_bunqto": false,\n      "amount": {\n        "currency": "",\n        "value": ""\n      },\n      "attachment": [\n        {\n          "id": 0,\n          "monetary_account_id": 0\n        }\n      ],\n      "balance_after_mutation": {},\n      "batch_id": 0,\n      "bunqto_expiry": "",\n      "bunqto_share_url": "",\n      "bunqto_status": "",\n      "bunqto_sub_status": "",\n      "bunqto_time_responded": "",\n      "counterparty_alias": {},\n      "created": "",\n      "description": "",\n      "geolocation": {\n        "altitude": 0,\n        "latitude": 0,\n        "longitude": 0,\n        "radius": 0\n      },\n      "id": 0,\n      "merchant_reference": "",\n      "monetary_account_id": 0,\n      "payment_auto_allocate_instance": {\n        "created": "",\n        "error_message": [],\n        "id": 0,\n        "payment_auto_allocate_id": 0,\n        "payment_batch": {\n          "payments": {\n            "Payment": []\n          }\n        },\n        "payment_id": 0,\n        "status": "",\n        "updated": ""\n      },\n      "request_reference_split_the_bill": [\n        {\n          "id": 0,\n          "type": ""\n        }\n      ],\n      "scheduled_id": 0,\n      "sub_type": "",\n      "type": "",\n      "updated": ""\n    }\n  ],\n  "reference": "",\n  "type": ""\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "description": "",
  "payments": [
    [
      "address_billing": [
        "city": "",
        "country": "",
        "extra": "",
        "house_number": "",
        "is_user_address_updated": false,
        "mailbox_name": "",
        "po_box": "",
        "postal_code": "",
        "province": "",
        "street": ""
      ],
      "address_shipping": [],
      "alias": [
        "avatar": [
          "anchor_uuid": "",
          "image": [
            [
              "attachment_public_uuid": "",
              "content_type": "",
              "height": 0,
              "width": 0
            ]
          ],
          "style": "",
          "uuid": ""
        ],
        "bunq_me": [
          "name": "",
          "service": "",
          "type": "",
          "value": ""
        ],
        "country": "",
        "display_name": "",
        "iban": "",
        "is_light": false,
        "label_user": [
          "avatar": [],
          "country": "",
          "display_name": "",
          "public_nick_name": "",
          "uuid": ""
        ],
        "merchant_category_code": "",
        "swift_account_number": "",
        "swift_bic": "",
        "transferwise_account_number": "",
        "transferwise_bank_code": ""
      ],
      "allow_bunqto": false,
      "amount": [
        "currency": "",
        "value": ""
      ],
      "attachment": [
        [
          "id": 0,
          "monetary_account_id": 0
        ]
      ],
      "balance_after_mutation": [],
      "batch_id": 0,
      "bunqto_expiry": "",
      "bunqto_share_url": "",
      "bunqto_status": "",
      "bunqto_sub_status": "",
      "bunqto_time_responded": "",
      "counterparty_alias": [],
      "created": "",
      "description": "",
      "geolocation": [
        "altitude": 0,
        "latitude": 0,
        "longitude": 0,
        "radius": 0
      ],
      "id": 0,
      "merchant_reference": "",
      "monetary_account_id": 0,
      "payment_auto_allocate_instance": [
        "created": "",
        "error_message": [],
        "id": 0,
        "payment_auto_allocate_id": 0,
        "payment_batch": ["payments": ["Payment": []]],
        "payment_id": 0,
        "status": "",
        "updated": ""
      ],
      "request_reference_split_the_bill": [
        [
          "id": 0,
          "type": ""
        ]
      ],
      "scheduled_id": 0,
      "sub_type": "",
      "type": "",
      "updated": ""
    ]
  ],
  "reference": "",
  "type": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction" {:headers {:user-agent ""
                                                                                                                             :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/translink-transaction HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/translink-transaction',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/translink-transaction", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/translink-transaction') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction/:itemId" {:headers {:user-agent ""
                                                                                                                                     :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/translink-transaction/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/translink-transaction/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/translink-transaction/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/translink-transaction/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/translink-transaction/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_TreeProgress_for_User
{{baseUrl}}/user/:userID/tree-progress
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/tree-progress");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/tree-progress" {:headers {:user-agent ""
                                                                                :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/tree-progress"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/tree-progress"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/tree-progress");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/tree-progress"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/tree-progress HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/tree-progress")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/tree-progress"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/tree-progress")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/tree-progress")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/tree-progress');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/tree-progress',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/tree-progress';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/tree-progress',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/tree-progress")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/tree-progress',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/tree-progress',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/tree-progress');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/tree-progress',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/tree-progress';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/tree-progress"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/tree-progress" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/tree-progress",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/tree-progress', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/tree-progress');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/tree-progress');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/tree-progress' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/tree-progress' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/tree-progress", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/tree-progress"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/tree-progress"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/tree-progress")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/tree-progress') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/tree-progress";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/tree-progress \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/tree-progress \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/tree-progress
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/tree-progress")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_User
{{baseUrl}}/user
HEADERS

User-Agent
X-Bunq-Client-Authentication
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user" {:headers {:user-agent ""
                                                          :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_User
{{baseUrl}}/user/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:itemId" {:headers {:user-agent ""
                                                                  :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_UserCompany
{{baseUrl}}/user-company/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user-company/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user-company/:itemId" {:headers {:user-agent ""
                                                                          :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user-company/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user-company/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user-company/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user-company/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user-company/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user-company/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user-company/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user-company/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user-company/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user-company/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user-company/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user-company/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user-company/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user-company/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user-company/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user-company/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user-company/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user-company/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user-company/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user-company/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user-company/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user-company/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user-company/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user-company/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user-company/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user-company/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user-company/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user-company/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user-company/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user-company/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user-company/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user-company/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user-company/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user-company/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user-company/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user-company/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user-company/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_UserCompany
{{baseUrl}}/user-company/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

itemId
BODY json

{
  "address_main": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_postal": {},
  "alias": [
    {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    }
  ],
  "avatar": {
    "anchor_uuid": "",
    "image": [
      {
        "attachment_public_uuid": "",
        "content_type": "",
        "height": 0,
        "width": 0
      }
    ],
    "style": "",
    "uuid": ""
  },
  "avatar_uuid": "",
  "billing_contract": [
    {
      "contract_date_end": "",
      "contract_date_start": "",
      "contract_version": 0,
      "created": "",
      "id": 0,
      "status": "",
      "sub_status": "",
      "subscription_type": "",
      "subscription_type_downgrade": "",
      "updated": ""
    }
  ],
  "chamber_of_commerce_number": "",
  "counter_bank_iban": "",
  "country": "",
  "created": "",
  "customer": {
    "billing_account_id": "",
    "created": "",
    "id": 0,
    "invoice_notification_preference": "",
    "updated": ""
  },
  "customer_limit": {
    "limit_amount_monthly": {
      "currency": "",
      "value": ""
    },
    "limit_card_debit_maestro": 0,
    "limit_card_debit_mastercard": 0,
    "limit_card_debit_wildcard": 0,
    "limit_card_replacement": 0,
    "limit_card_wildcard": 0,
    "limit_monetary_account": 0,
    "limit_monetary_account_remaining": 0,
    "spent_amount_monthly": {}
  },
  "daily_limit_without_confirmation_login": {},
  "deny_reason": "",
  "directors": [
    {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    }
  ],
  "display_name": "",
  "id": 0,
  "language": "",
  "legal_form": "",
  "name": "",
  "notification_filters": [
    {
      "category": "",
      "notification_delivery_method": "",
      "notification_target": ""
    }
  ],
  "public_nick_name": "",
  "public_uuid": "",
  "region": "",
  "relations": [
    {
      "counter_label_user": {},
      "counter_user_id": "",
      "counter_user_status": "",
      "label_user": {},
      "relationship": "",
      "status": "",
      "user_id": "",
      "user_status": ""
    }
  ],
  "sector_of_industry": "",
  "session_timeout": 0,
  "status": "",
  "sub_status": "",
  "tax_resident": [
    {
      "country": "",
      "status": "",
      "tax_number": ""
    }
  ],
  "type_of_business_entity": "",
  "ubo": [
    {
      "date_of_birth": "",
      "name": "",
      "nationality": ""
    }
  ],
  "updated": "",
  "version_terms_of_service": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user-company/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"avatar\": {\n    \"anchor_uuid\": \"\",\n    \"image\": [\n      {\n        \"attachment_public_uuid\": \"\",\n        \"content_type\": \"\",\n        \"height\": 0,\n        \"width\": 0\n      }\n    ],\n    \"style\": \"\",\n    \"uuid\": \"\"\n  },\n  \"avatar_uuid\": \"\",\n  \"billing_contract\": [\n    {\n      \"contract_date_end\": \"\",\n      \"contract_date_start\": \"\",\n      \"contract_version\": 0,\n      \"created\": \"\",\n      \"id\": 0,\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"subscription_type\": \"\",\n      \"subscription_type_downgrade\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"chamber_of_commerce_number\": \"\",\n  \"counter_bank_iban\": \"\",\n  \"country\": \"\",\n  \"created\": \"\",\n  \"customer\": {\n    \"billing_account_id\": \"\",\n    \"created\": \"\",\n    \"id\": 0,\n    \"invoice_notification_preference\": \"\",\n    \"updated\": \"\"\n  },\n  \"customer_limit\": {\n    \"limit_amount_monthly\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"limit_card_debit_maestro\": 0,\n    \"limit_card_debit_mastercard\": 0,\n    \"limit_card_debit_wildcard\": 0,\n    \"limit_card_replacement\": 0,\n    \"limit_card_wildcard\": 0,\n    \"limit_monetary_account\": 0,\n    \"limit_monetary_account_remaining\": 0,\n    \"spent_amount_monthly\": {}\n  },\n  \"daily_limit_without_confirmation_login\": {},\n  \"deny_reason\": \"\",\n  \"directors\": [\n    {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    }\n  ],\n  \"display_name\": \"\",\n  \"id\": 0,\n  \"language\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"notification_filters\": [\n    {\n      \"category\": \"\",\n      \"notification_delivery_method\": \"\",\n      \"notification_target\": \"\"\n    }\n  ],\n  \"public_nick_name\": \"\",\n  \"public_uuid\": \"\",\n  \"region\": \"\",\n  \"relations\": [\n    {\n      \"counter_label_user\": {},\n      \"counter_user_id\": \"\",\n      \"counter_user_status\": \"\",\n      \"label_user\": {},\n      \"relationship\": \"\",\n      \"status\": \"\",\n      \"user_id\": \"\",\n      \"user_status\": \"\"\n    }\n  ],\n  \"sector_of_industry\": \"\",\n  \"session_timeout\": 0,\n  \"status\": \"\",\n  \"sub_status\": \"\",\n  \"tax_resident\": [\n    {\n      \"country\": \"\",\n      \"status\": \"\",\n      \"tax_number\": \"\"\n    }\n  ],\n  \"type_of_business_entity\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"updated\": \"\",\n  \"version_terms_of_service\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user-company/:itemId" {:headers {:user-agent ""
                                                                          :x-bunq-client-authentication ""}
                                                                :content-type :json
                                                                :form-params {:address_main {:city ""
                                                                                             :country ""
                                                                                             :extra ""
                                                                                             :house_number ""
                                                                                             :is_user_address_updated false
                                                                                             :mailbox_name ""
                                                                                             :po_box ""
                                                                                             :postal_code ""
                                                                                             :province ""
                                                                                             :street ""}
                                                                              :address_postal {}
                                                                              :alias [{:name ""
                                                                                       :service ""
                                                                                       :type ""
                                                                                       :value ""}]
                                                                              :avatar {:anchor_uuid ""
                                                                                       :image [{:attachment_public_uuid ""
                                                                                                :content_type ""
                                                                                                :height 0
                                                                                                :width 0}]
                                                                                       :style ""
                                                                                       :uuid ""}
                                                                              :avatar_uuid ""
                                                                              :billing_contract [{:contract_date_end ""
                                                                                                  :contract_date_start ""
                                                                                                  :contract_version 0
                                                                                                  :created ""
                                                                                                  :id 0
                                                                                                  :status ""
                                                                                                  :sub_status ""
                                                                                                  :subscription_type ""
                                                                                                  :subscription_type_downgrade ""
                                                                                                  :updated ""}]
                                                                              :chamber_of_commerce_number ""
                                                                              :counter_bank_iban ""
                                                                              :country ""
                                                                              :created ""
                                                                              :customer {:billing_account_id ""
                                                                                         :created ""
                                                                                         :id 0
                                                                                         :invoice_notification_preference ""
                                                                                         :updated ""}
                                                                              :customer_limit {:limit_amount_monthly {:currency ""
                                                                                                                      :value ""}
                                                                                               :limit_card_debit_maestro 0
                                                                                               :limit_card_debit_mastercard 0
                                                                                               :limit_card_debit_wildcard 0
                                                                                               :limit_card_replacement 0
                                                                                               :limit_card_wildcard 0
                                                                                               :limit_monetary_account 0
                                                                                               :limit_monetary_account_remaining 0
                                                                                               :spent_amount_monthly {}}
                                                                              :daily_limit_without_confirmation_login {}
                                                                              :deny_reason ""
                                                                              :directors [{:avatar {}
                                                                                           :country ""
                                                                                           :display_name ""
                                                                                           :public_nick_name ""
                                                                                           :uuid ""}]
                                                                              :display_name ""
                                                                              :id 0
                                                                              :language ""
                                                                              :legal_form ""
                                                                              :name ""
                                                                              :notification_filters [{:category ""
                                                                                                      :notification_delivery_method ""
                                                                                                      :notification_target ""}]
                                                                              :public_nick_name ""
                                                                              :public_uuid ""
                                                                              :region ""
                                                                              :relations [{:counter_label_user {}
                                                                                           :counter_user_id ""
                                                                                           :counter_user_status ""
                                                                                           :label_user {}
                                                                                           :relationship ""
                                                                                           :status ""
                                                                                           :user_id ""
                                                                                           :user_status ""}]
                                                                              :sector_of_industry ""
                                                                              :session_timeout 0
                                                                              :status ""
                                                                              :sub_status ""
                                                                              :tax_resident [{:country ""
                                                                                              :status ""
                                                                                              :tax_number ""}]
                                                                              :type_of_business_entity ""
                                                                              :ubo [{:date_of_birth ""
                                                                                     :name ""
                                                                                     :nationality ""}]
                                                                              :updated ""
                                                                              :version_terms_of_service ""}})
require "http/client"

url = "{{baseUrl}}/user-company/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"avatar\": {\n    \"anchor_uuid\": \"\",\n    \"image\": [\n      {\n        \"attachment_public_uuid\": \"\",\n        \"content_type\": \"\",\n        \"height\": 0,\n        \"width\": 0\n      }\n    ],\n    \"style\": \"\",\n    \"uuid\": \"\"\n  },\n  \"avatar_uuid\": \"\",\n  \"billing_contract\": [\n    {\n      \"contract_date_end\": \"\",\n      \"contract_date_start\": \"\",\n      \"contract_version\": 0,\n      \"created\": \"\",\n      \"id\": 0,\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"subscription_type\": \"\",\n      \"subscription_type_downgrade\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"chamber_of_commerce_number\": \"\",\n  \"counter_bank_iban\": \"\",\n  \"country\": \"\",\n  \"created\": \"\",\n  \"customer\": {\n    \"billing_account_id\": \"\",\n    \"created\": \"\",\n    \"id\": 0,\n    \"invoice_notification_preference\": \"\",\n    \"updated\": \"\"\n  },\n  \"customer_limit\": {\n    \"limit_amount_monthly\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"limit_card_debit_maestro\": 0,\n    \"limit_card_debit_mastercard\": 0,\n    \"limit_card_debit_wildcard\": 0,\n    \"limit_card_replacement\": 0,\n    \"limit_card_wildcard\": 0,\n    \"limit_monetary_account\": 0,\n    \"limit_monetary_account_remaining\": 0,\n    \"spent_amount_monthly\": {}\n  },\n  \"daily_limit_without_confirmation_login\": {},\n  \"deny_reason\": \"\",\n  \"directors\": [\n    {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    }\n  ],\n  \"display_name\": \"\",\n  \"id\": 0,\n  \"language\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"notification_filters\": [\n    {\n      \"category\": \"\",\n      \"notification_delivery_method\": \"\",\n      \"notification_target\": \"\"\n    }\n  ],\n  \"public_nick_name\": \"\",\n  \"public_uuid\": \"\",\n  \"region\": \"\",\n  \"relations\": [\n    {\n      \"counter_label_user\": {},\n      \"counter_user_id\": \"\",\n      \"counter_user_status\": \"\",\n      \"label_user\": {},\n      \"relationship\": \"\",\n      \"status\": \"\",\n      \"user_id\": \"\",\n      \"user_status\": \"\"\n    }\n  ],\n  \"sector_of_industry\": \"\",\n  \"session_timeout\": 0,\n  \"status\": \"\",\n  \"sub_status\": \"\",\n  \"tax_resident\": [\n    {\n      \"country\": \"\",\n      \"status\": \"\",\n      \"tax_number\": \"\"\n    }\n  ],\n  \"type_of_business_entity\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"updated\": \"\",\n  \"version_terms_of_service\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user-company/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"avatar\": {\n    \"anchor_uuid\": \"\",\n    \"image\": [\n      {\n        \"attachment_public_uuid\": \"\",\n        \"content_type\": \"\",\n        \"height\": 0,\n        \"width\": 0\n      }\n    ],\n    \"style\": \"\",\n    \"uuid\": \"\"\n  },\n  \"avatar_uuid\": \"\",\n  \"billing_contract\": [\n    {\n      \"contract_date_end\": \"\",\n      \"contract_date_start\": \"\",\n      \"contract_version\": 0,\n      \"created\": \"\",\n      \"id\": 0,\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"subscription_type\": \"\",\n      \"subscription_type_downgrade\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"chamber_of_commerce_number\": \"\",\n  \"counter_bank_iban\": \"\",\n  \"country\": \"\",\n  \"created\": \"\",\n  \"customer\": {\n    \"billing_account_id\": \"\",\n    \"created\": \"\",\n    \"id\": 0,\n    \"invoice_notification_preference\": \"\",\n    \"updated\": \"\"\n  },\n  \"customer_limit\": {\n    \"limit_amount_monthly\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"limit_card_debit_maestro\": 0,\n    \"limit_card_debit_mastercard\": 0,\n    \"limit_card_debit_wildcard\": 0,\n    \"limit_card_replacement\": 0,\n    \"limit_card_wildcard\": 0,\n    \"limit_monetary_account\": 0,\n    \"limit_monetary_account_remaining\": 0,\n    \"spent_amount_monthly\": {}\n  },\n  \"daily_limit_without_confirmation_login\": {},\n  \"deny_reason\": \"\",\n  \"directors\": [\n    {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    }\n  ],\n  \"display_name\": \"\",\n  \"id\": 0,\n  \"language\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"notification_filters\": [\n    {\n      \"category\": \"\",\n      \"notification_delivery_method\": \"\",\n      \"notification_target\": \"\"\n    }\n  ],\n  \"public_nick_name\": \"\",\n  \"public_uuid\": \"\",\n  \"region\": \"\",\n  \"relations\": [\n    {\n      \"counter_label_user\": {},\n      \"counter_user_id\": \"\",\n      \"counter_user_status\": \"\",\n      \"label_user\": {},\n      \"relationship\": \"\",\n      \"status\": \"\",\n      \"user_id\": \"\",\n      \"user_status\": \"\"\n    }\n  ],\n  \"sector_of_industry\": \"\",\n  \"session_timeout\": 0,\n  \"status\": \"\",\n  \"sub_status\": \"\",\n  \"tax_resident\": [\n    {\n      \"country\": \"\",\n      \"status\": \"\",\n      \"tax_number\": \"\"\n    }\n  ],\n  \"type_of_business_entity\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"updated\": \"\",\n  \"version_terms_of_service\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user-company/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"avatar\": {\n    \"anchor_uuid\": \"\",\n    \"image\": [\n      {\n        \"attachment_public_uuid\": \"\",\n        \"content_type\": \"\",\n        \"height\": 0,\n        \"width\": 0\n      }\n    ],\n    \"style\": \"\",\n    \"uuid\": \"\"\n  },\n  \"avatar_uuid\": \"\",\n  \"billing_contract\": [\n    {\n      \"contract_date_end\": \"\",\n      \"contract_date_start\": \"\",\n      \"contract_version\": 0,\n      \"created\": \"\",\n      \"id\": 0,\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"subscription_type\": \"\",\n      \"subscription_type_downgrade\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"chamber_of_commerce_number\": \"\",\n  \"counter_bank_iban\": \"\",\n  \"country\": \"\",\n  \"created\": \"\",\n  \"customer\": {\n    \"billing_account_id\": \"\",\n    \"created\": \"\",\n    \"id\": 0,\n    \"invoice_notification_preference\": \"\",\n    \"updated\": \"\"\n  },\n  \"customer_limit\": {\n    \"limit_amount_monthly\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"limit_card_debit_maestro\": 0,\n    \"limit_card_debit_mastercard\": 0,\n    \"limit_card_debit_wildcard\": 0,\n    \"limit_card_replacement\": 0,\n    \"limit_card_wildcard\": 0,\n    \"limit_monetary_account\": 0,\n    \"limit_monetary_account_remaining\": 0,\n    \"spent_amount_monthly\": {}\n  },\n  \"daily_limit_without_confirmation_login\": {},\n  \"deny_reason\": \"\",\n  \"directors\": [\n    {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    }\n  ],\n  \"display_name\": \"\",\n  \"id\": 0,\n  \"language\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"notification_filters\": [\n    {\n      \"category\": \"\",\n      \"notification_delivery_method\": \"\",\n      \"notification_target\": \"\"\n    }\n  ],\n  \"public_nick_name\": \"\",\n  \"public_uuid\": \"\",\n  \"region\": \"\",\n  \"relations\": [\n    {\n      \"counter_label_user\": {},\n      \"counter_user_id\": \"\",\n      \"counter_user_status\": \"\",\n      \"label_user\": {},\n      \"relationship\": \"\",\n      \"status\": \"\",\n      \"user_id\": \"\",\n      \"user_status\": \"\"\n    }\n  ],\n  \"sector_of_industry\": \"\",\n  \"session_timeout\": 0,\n  \"status\": \"\",\n  \"sub_status\": \"\",\n  \"tax_resident\": [\n    {\n      \"country\": \"\",\n      \"status\": \"\",\n      \"tax_number\": \"\"\n    }\n  ],\n  \"type_of_business_entity\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"updated\": \"\",\n  \"version_terms_of_service\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user-company/:itemId"

	payload := strings.NewReader("{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"avatar\": {\n    \"anchor_uuid\": \"\",\n    \"image\": [\n      {\n        \"attachment_public_uuid\": \"\",\n        \"content_type\": \"\",\n        \"height\": 0,\n        \"width\": 0\n      }\n    ],\n    \"style\": \"\",\n    \"uuid\": \"\"\n  },\n  \"avatar_uuid\": \"\",\n  \"billing_contract\": [\n    {\n      \"contract_date_end\": \"\",\n      \"contract_date_start\": \"\",\n      \"contract_version\": 0,\n      \"created\": \"\",\n      \"id\": 0,\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"subscription_type\": \"\",\n      \"subscription_type_downgrade\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"chamber_of_commerce_number\": \"\",\n  \"counter_bank_iban\": \"\",\n  \"country\": \"\",\n  \"created\": \"\",\n  \"customer\": {\n    \"billing_account_id\": \"\",\n    \"created\": \"\",\n    \"id\": 0,\n    \"invoice_notification_preference\": \"\",\n    \"updated\": \"\"\n  },\n  \"customer_limit\": {\n    \"limit_amount_monthly\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"limit_card_debit_maestro\": 0,\n    \"limit_card_debit_mastercard\": 0,\n    \"limit_card_debit_wildcard\": 0,\n    \"limit_card_replacement\": 0,\n    \"limit_card_wildcard\": 0,\n    \"limit_monetary_account\": 0,\n    \"limit_monetary_account_remaining\": 0,\n    \"spent_amount_monthly\": {}\n  },\n  \"daily_limit_without_confirmation_login\": {},\n  \"deny_reason\": \"\",\n  \"directors\": [\n    {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    }\n  ],\n  \"display_name\": \"\",\n  \"id\": 0,\n  \"language\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"notification_filters\": [\n    {\n      \"category\": \"\",\n      \"notification_delivery_method\": \"\",\n      \"notification_target\": \"\"\n    }\n  ],\n  \"public_nick_name\": \"\",\n  \"public_uuid\": \"\",\n  \"region\": \"\",\n  \"relations\": [\n    {\n      \"counter_label_user\": {},\n      \"counter_user_id\": \"\",\n      \"counter_user_status\": \"\",\n      \"label_user\": {},\n      \"relationship\": \"\",\n      \"status\": \"\",\n      \"user_id\": \"\",\n      \"user_status\": \"\"\n    }\n  ],\n  \"sector_of_industry\": \"\",\n  \"session_timeout\": 0,\n  \"status\": \"\",\n  \"sub_status\": \"\",\n  \"tax_resident\": [\n    {\n      \"country\": \"\",\n      \"status\": \"\",\n      \"tax_number\": \"\"\n    }\n  ],\n  \"type_of_business_entity\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"updated\": \"\",\n  \"version_terms_of_service\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user-company/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 2660

{
  "address_main": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_postal": {},
  "alias": [
    {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    }
  ],
  "avatar": {
    "anchor_uuid": "",
    "image": [
      {
        "attachment_public_uuid": "",
        "content_type": "",
        "height": 0,
        "width": 0
      }
    ],
    "style": "",
    "uuid": ""
  },
  "avatar_uuid": "",
  "billing_contract": [
    {
      "contract_date_end": "",
      "contract_date_start": "",
      "contract_version": 0,
      "created": "",
      "id": 0,
      "status": "",
      "sub_status": "",
      "subscription_type": "",
      "subscription_type_downgrade": "",
      "updated": ""
    }
  ],
  "chamber_of_commerce_number": "",
  "counter_bank_iban": "",
  "country": "",
  "created": "",
  "customer": {
    "billing_account_id": "",
    "created": "",
    "id": 0,
    "invoice_notification_preference": "",
    "updated": ""
  },
  "customer_limit": {
    "limit_amount_monthly": {
      "currency": "",
      "value": ""
    },
    "limit_card_debit_maestro": 0,
    "limit_card_debit_mastercard": 0,
    "limit_card_debit_wildcard": 0,
    "limit_card_replacement": 0,
    "limit_card_wildcard": 0,
    "limit_monetary_account": 0,
    "limit_monetary_account_remaining": 0,
    "spent_amount_monthly": {}
  },
  "daily_limit_without_confirmation_login": {},
  "deny_reason": "",
  "directors": [
    {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    }
  ],
  "display_name": "",
  "id": 0,
  "language": "",
  "legal_form": "",
  "name": "",
  "notification_filters": [
    {
      "category": "",
      "notification_delivery_method": "",
      "notification_target": ""
    }
  ],
  "public_nick_name": "",
  "public_uuid": "",
  "region": "",
  "relations": [
    {
      "counter_label_user": {},
      "counter_user_id": "",
      "counter_user_status": "",
      "label_user": {},
      "relationship": "",
      "status": "",
      "user_id": "",
      "user_status": ""
    }
  ],
  "sector_of_industry": "",
  "session_timeout": 0,
  "status": "",
  "sub_status": "",
  "tax_resident": [
    {
      "country": "",
      "status": "",
      "tax_number": ""
    }
  ],
  "type_of_business_entity": "",
  "ubo": [
    {
      "date_of_birth": "",
      "name": "",
      "nationality": ""
    }
  ],
  "updated": "",
  "version_terms_of_service": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user-company/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"avatar\": {\n    \"anchor_uuid\": \"\",\n    \"image\": [\n      {\n        \"attachment_public_uuid\": \"\",\n        \"content_type\": \"\",\n        \"height\": 0,\n        \"width\": 0\n      }\n    ],\n    \"style\": \"\",\n    \"uuid\": \"\"\n  },\n  \"avatar_uuid\": \"\",\n  \"billing_contract\": [\n    {\n      \"contract_date_end\": \"\",\n      \"contract_date_start\": \"\",\n      \"contract_version\": 0,\n      \"created\": \"\",\n      \"id\": 0,\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"subscription_type\": \"\",\n      \"subscription_type_downgrade\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"chamber_of_commerce_number\": \"\",\n  \"counter_bank_iban\": \"\",\n  \"country\": \"\",\n  \"created\": \"\",\n  \"customer\": {\n    \"billing_account_id\": \"\",\n    \"created\": \"\",\n    \"id\": 0,\n    \"invoice_notification_preference\": \"\",\n    \"updated\": \"\"\n  },\n  \"customer_limit\": {\n    \"limit_amount_monthly\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"limit_card_debit_maestro\": 0,\n    \"limit_card_debit_mastercard\": 0,\n    \"limit_card_debit_wildcard\": 0,\n    \"limit_card_replacement\": 0,\n    \"limit_card_wildcard\": 0,\n    \"limit_monetary_account\": 0,\n    \"limit_monetary_account_remaining\": 0,\n    \"spent_amount_monthly\": {}\n  },\n  \"daily_limit_without_confirmation_login\": {},\n  \"deny_reason\": \"\",\n  \"directors\": [\n    {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    }\n  ],\n  \"display_name\": \"\",\n  \"id\": 0,\n  \"language\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"notification_filters\": [\n    {\n      \"category\": \"\",\n      \"notification_delivery_method\": \"\",\n      \"notification_target\": \"\"\n    }\n  ],\n  \"public_nick_name\": \"\",\n  \"public_uuid\": \"\",\n  \"region\": \"\",\n  \"relations\": [\n    {\n      \"counter_label_user\": {},\n      \"counter_user_id\": \"\",\n      \"counter_user_status\": \"\",\n      \"label_user\": {},\n      \"relationship\": \"\",\n      \"status\": \"\",\n      \"user_id\": \"\",\n      \"user_status\": \"\"\n    }\n  ],\n  \"sector_of_industry\": \"\",\n  \"session_timeout\": 0,\n  \"status\": \"\",\n  \"sub_status\": \"\",\n  \"tax_resident\": [\n    {\n      \"country\": \"\",\n      \"status\": \"\",\n      \"tax_number\": \"\"\n    }\n  ],\n  \"type_of_business_entity\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"updated\": \"\",\n  \"version_terms_of_service\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user-company/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"avatar\": {\n    \"anchor_uuid\": \"\",\n    \"image\": [\n      {\n        \"attachment_public_uuid\": \"\",\n        \"content_type\": \"\",\n        \"height\": 0,\n        \"width\": 0\n      }\n    ],\n    \"style\": \"\",\n    \"uuid\": \"\"\n  },\n  \"avatar_uuid\": \"\",\n  \"billing_contract\": [\n    {\n      \"contract_date_end\": \"\",\n      \"contract_date_start\": \"\",\n      \"contract_version\": 0,\n      \"created\": \"\",\n      \"id\": 0,\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"subscription_type\": \"\",\n      \"subscription_type_downgrade\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"chamber_of_commerce_number\": \"\",\n  \"counter_bank_iban\": \"\",\n  \"country\": \"\",\n  \"created\": \"\",\n  \"customer\": {\n    \"billing_account_id\": \"\",\n    \"created\": \"\",\n    \"id\": 0,\n    \"invoice_notification_preference\": \"\",\n    \"updated\": \"\"\n  },\n  \"customer_limit\": {\n    \"limit_amount_monthly\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"limit_card_debit_maestro\": 0,\n    \"limit_card_debit_mastercard\": 0,\n    \"limit_card_debit_wildcard\": 0,\n    \"limit_card_replacement\": 0,\n    \"limit_card_wildcard\": 0,\n    \"limit_monetary_account\": 0,\n    \"limit_monetary_account_remaining\": 0,\n    \"spent_amount_monthly\": {}\n  },\n  \"daily_limit_without_confirmation_login\": {},\n  \"deny_reason\": \"\",\n  \"directors\": [\n    {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    }\n  ],\n  \"display_name\": \"\",\n  \"id\": 0,\n  \"language\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"notification_filters\": [\n    {\n      \"category\": \"\",\n      \"notification_delivery_method\": \"\",\n      \"notification_target\": \"\"\n    }\n  ],\n  \"public_nick_name\": \"\",\n  \"public_uuid\": \"\",\n  \"region\": \"\",\n  \"relations\": [\n    {\n      \"counter_label_user\": {},\n      \"counter_user_id\": \"\",\n      \"counter_user_status\": \"\",\n      \"label_user\": {},\n      \"relationship\": \"\",\n      \"status\": \"\",\n      \"user_id\": \"\",\n      \"user_status\": \"\"\n    }\n  ],\n  \"sector_of_industry\": \"\",\n  \"session_timeout\": 0,\n  \"status\": \"\",\n  \"sub_status\": \"\",\n  \"tax_resident\": [\n    {\n      \"country\": \"\",\n      \"status\": \"\",\n      \"tax_number\": \"\"\n    }\n  ],\n  \"type_of_business_entity\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"updated\": \"\",\n  \"version_terms_of_service\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"avatar\": {\n    \"anchor_uuid\": \"\",\n    \"image\": [\n      {\n        \"attachment_public_uuid\": \"\",\n        \"content_type\": \"\",\n        \"height\": 0,\n        \"width\": 0\n      }\n    ],\n    \"style\": \"\",\n    \"uuid\": \"\"\n  },\n  \"avatar_uuid\": \"\",\n  \"billing_contract\": [\n    {\n      \"contract_date_end\": \"\",\n      \"contract_date_start\": \"\",\n      \"contract_version\": 0,\n      \"created\": \"\",\n      \"id\": 0,\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"subscription_type\": \"\",\n      \"subscription_type_downgrade\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"chamber_of_commerce_number\": \"\",\n  \"counter_bank_iban\": \"\",\n  \"country\": \"\",\n  \"created\": \"\",\n  \"customer\": {\n    \"billing_account_id\": \"\",\n    \"created\": \"\",\n    \"id\": 0,\n    \"invoice_notification_preference\": \"\",\n    \"updated\": \"\"\n  },\n  \"customer_limit\": {\n    \"limit_amount_monthly\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"limit_card_debit_maestro\": 0,\n    \"limit_card_debit_mastercard\": 0,\n    \"limit_card_debit_wildcard\": 0,\n    \"limit_card_replacement\": 0,\n    \"limit_card_wildcard\": 0,\n    \"limit_monetary_account\": 0,\n    \"limit_monetary_account_remaining\": 0,\n    \"spent_amount_monthly\": {}\n  },\n  \"daily_limit_without_confirmation_login\": {},\n  \"deny_reason\": \"\",\n  \"directors\": [\n    {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    }\n  ],\n  \"display_name\": \"\",\n  \"id\": 0,\n  \"language\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"notification_filters\": [\n    {\n      \"category\": \"\",\n      \"notification_delivery_method\": \"\",\n      \"notification_target\": \"\"\n    }\n  ],\n  \"public_nick_name\": \"\",\n  \"public_uuid\": \"\",\n  \"region\": \"\",\n  \"relations\": [\n    {\n      \"counter_label_user\": {},\n      \"counter_user_id\": \"\",\n      \"counter_user_status\": \"\",\n      \"label_user\": {},\n      \"relationship\": \"\",\n      \"status\": \"\",\n      \"user_id\": \"\",\n      \"user_status\": \"\"\n    }\n  ],\n  \"sector_of_industry\": \"\",\n  \"session_timeout\": 0,\n  \"status\": \"\",\n  \"sub_status\": \"\",\n  \"tax_resident\": [\n    {\n      \"country\": \"\",\n      \"status\": \"\",\n      \"tax_number\": \"\"\n    }\n  ],\n  \"type_of_business_entity\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"updated\": \"\",\n  \"version_terms_of_service\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user-company/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user-company/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"avatar\": {\n    \"anchor_uuid\": \"\",\n    \"image\": [\n      {\n        \"attachment_public_uuid\": \"\",\n        \"content_type\": \"\",\n        \"height\": 0,\n        \"width\": 0\n      }\n    ],\n    \"style\": \"\",\n    \"uuid\": \"\"\n  },\n  \"avatar_uuid\": \"\",\n  \"billing_contract\": [\n    {\n      \"contract_date_end\": \"\",\n      \"contract_date_start\": \"\",\n      \"contract_version\": 0,\n      \"created\": \"\",\n      \"id\": 0,\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"subscription_type\": \"\",\n      \"subscription_type_downgrade\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"chamber_of_commerce_number\": \"\",\n  \"counter_bank_iban\": \"\",\n  \"country\": \"\",\n  \"created\": \"\",\n  \"customer\": {\n    \"billing_account_id\": \"\",\n    \"created\": \"\",\n    \"id\": 0,\n    \"invoice_notification_preference\": \"\",\n    \"updated\": \"\"\n  },\n  \"customer_limit\": {\n    \"limit_amount_monthly\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"limit_card_debit_maestro\": 0,\n    \"limit_card_debit_mastercard\": 0,\n    \"limit_card_debit_wildcard\": 0,\n    \"limit_card_replacement\": 0,\n    \"limit_card_wildcard\": 0,\n    \"limit_monetary_account\": 0,\n    \"limit_monetary_account_remaining\": 0,\n    \"spent_amount_monthly\": {}\n  },\n  \"daily_limit_without_confirmation_login\": {},\n  \"deny_reason\": \"\",\n  \"directors\": [\n    {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    }\n  ],\n  \"display_name\": \"\",\n  \"id\": 0,\n  \"language\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"notification_filters\": [\n    {\n      \"category\": \"\",\n      \"notification_delivery_method\": \"\",\n      \"notification_target\": \"\"\n    }\n  ],\n  \"public_nick_name\": \"\",\n  \"public_uuid\": \"\",\n  \"region\": \"\",\n  \"relations\": [\n    {\n      \"counter_label_user\": {},\n      \"counter_user_id\": \"\",\n      \"counter_user_status\": \"\",\n      \"label_user\": {},\n      \"relationship\": \"\",\n      \"status\": \"\",\n      \"user_id\": \"\",\n      \"user_status\": \"\"\n    }\n  ],\n  \"sector_of_industry\": \"\",\n  \"session_timeout\": 0,\n  \"status\": \"\",\n  \"sub_status\": \"\",\n  \"tax_resident\": [\n    {\n      \"country\": \"\",\n      \"status\": \"\",\n      \"tax_number\": \"\"\n    }\n  ],\n  \"type_of_business_entity\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"updated\": \"\",\n  \"version_terms_of_service\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  address_main: {
    city: '',
    country: '',
    extra: '',
    house_number: '',
    is_user_address_updated: false,
    mailbox_name: '',
    po_box: '',
    postal_code: '',
    province: '',
    street: ''
  },
  address_postal: {},
  alias: [
    {
      name: '',
      service: '',
      type: '',
      value: ''
    }
  ],
  avatar: {
    anchor_uuid: '',
    image: [
      {
        attachment_public_uuid: '',
        content_type: '',
        height: 0,
        width: 0
      }
    ],
    style: '',
    uuid: ''
  },
  avatar_uuid: '',
  billing_contract: [
    {
      contract_date_end: '',
      contract_date_start: '',
      contract_version: 0,
      created: '',
      id: 0,
      status: '',
      sub_status: '',
      subscription_type: '',
      subscription_type_downgrade: '',
      updated: ''
    }
  ],
  chamber_of_commerce_number: '',
  counter_bank_iban: '',
  country: '',
  created: '',
  customer: {
    billing_account_id: '',
    created: '',
    id: 0,
    invoice_notification_preference: '',
    updated: ''
  },
  customer_limit: {
    limit_amount_monthly: {
      currency: '',
      value: ''
    },
    limit_card_debit_maestro: 0,
    limit_card_debit_mastercard: 0,
    limit_card_debit_wildcard: 0,
    limit_card_replacement: 0,
    limit_card_wildcard: 0,
    limit_monetary_account: 0,
    limit_monetary_account_remaining: 0,
    spent_amount_monthly: {}
  },
  daily_limit_without_confirmation_login: {},
  deny_reason: '',
  directors: [
    {
      avatar: {},
      country: '',
      display_name: '',
      public_nick_name: '',
      uuid: ''
    }
  ],
  display_name: '',
  id: 0,
  language: '',
  legal_form: '',
  name: '',
  notification_filters: [
    {
      category: '',
      notification_delivery_method: '',
      notification_target: ''
    }
  ],
  public_nick_name: '',
  public_uuid: '',
  region: '',
  relations: [
    {
      counter_label_user: {},
      counter_user_id: '',
      counter_user_status: '',
      label_user: {},
      relationship: '',
      status: '',
      user_id: '',
      user_status: ''
    }
  ],
  sector_of_industry: '',
  session_timeout: 0,
  status: '',
  sub_status: '',
  tax_resident: [
    {
      country: '',
      status: '',
      tax_number: ''
    }
  ],
  type_of_business_entity: '',
  ubo: [
    {
      date_of_birth: '',
      name: '',
      nationality: ''
    }
  ],
  updated: '',
  version_terms_of_service: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user-company/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user-company/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    address_main: {
      city: '',
      country: '',
      extra: '',
      house_number: '',
      is_user_address_updated: false,
      mailbox_name: '',
      po_box: '',
      postal_code: '',
      province: '',
      street: ''
    },
    address_postal: {},
    alias: [{name: '', service: '', type: '', value: ''}],
    avatar: {
      anchor_uuid: '',
      image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
      style: '',
      uuid: ''
    },
    avatar_uuid: '',
    billing_contract: [
      {
        contract_date_end: '',
        contract_date_start: '',
        contract_version: 0,
        created: '',
        id: 0,
        status: '',
        sub_status: '',
        subscription_type: '',
        subscription_type_downgrade: '',
        updated: ''
      }
    ],
    chamber_of_commerce_number: '',
    counter_bank_iban: '',
    country: '',
    created: '',
    customer: {
      billing_account_id: '',
      created: '',
      id: 0,
      invoice_notification_preference: '',
      updated: ''
    },
    customer_limit: {
      limit_amount_monthly: {currency: '', value: ''},
      limit_card_debit_maestro: 0,
      limit_card_debit_mastercard: 0,
      limit_card_debit_wildcard: 0,
      limit_card_replacement: 0,
      limit_card_wildcard: 0,
      limit_monetary_account: 0,
      limit_monetary_account_remaining: 0,
      spent_amount_monthly: {}
    },
    daily_limit_without_confirmation_login: {},
    deny_reason: '',
    directors: [{avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''}],
    display_name: '',
    id: 0,
    language: '',
    legal_form: '',
    name: '',
    notification_filters: [{category: '', notification_delivery_method: '', notification_target: ''}],
    public_nick_name: '',
    public_uuid: '',
    region: '',
    relations: [
      {
        counter_label_user: {},
        counter_user_id: '',
        counter_user_status: '',
        label_user: {},
        relationship: '',
        status: '',
        user_id: '',
        user_status: ''
      }
    ],
    sector_of_industry: '',
    session_timeout: 0,
    status: '',
    sub_status: '',
    tax_resident: [{country: '', status: '', tax_number: ''}],
    type_of_business_entity: '',
    ubo: [{date_of_birth: '', name: '', nationality: ''}],
    updated: '',
    version_terms_of_service: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user-company/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"address_main":{"city":"","country":"","extra":"","house_number":"","is_user_address_updated":false,"mailbox_name":"","po_box":"","postal_code":"","province":"","street":""},"address_postal":{},"alias":[{"name":"","service":"","type":"","value":""}],"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"avatar_uuid":"","billing_contract":[{"contract_date_end":"","contract_date_start":"","contract_version":0,"created":"","id":0,"status":"","sub_status":"","subscription_type":"","subscription_type_downgrade":"","updated":""}],"chamber_of_commerce_number":"","counter_bank_iban":"","country":"","created":"","customer":{"billing_account_id":"","created":"","id":0,"invoice_notification_preference":"","updated":""},"customer_limit":{"limit_amount_monthly":{"currency":"","value":""},"limit_card_debit_maestro":0,"limit_card_debit_mastercard":0,"limit_card_debit_wildcard":0,"limit_card_replacement":0,"limit_card_wildcard":0,"limit_monetary_account":0,"limit_monetary_account_remaining":0,"spent_amount_monthly":{}},"daily_limit_without_confirmation_login":{},"deny_reason":"","directors":[{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""}],"display_name":"","id":0,"language":"","legal_form":"","name":"","notification_filters":[{"category":"","notification_delivery_method":"","notification_target":""}],"public_nick_name":"","public_uuid":"","region":"","relations":[{"counter_label_user":{},"counter_user_id":"","counter_user_status":"","label_user":{},"relationship":"","status":"","user_id":"","user_status":""}],"sector_of_industry":"","session_timeout":0,"status":"","sub_status":"","tax_resident":[{"country":"","status":"","tax_number":""}],"type_of_business_entity":"","ubo":[{"date_of_birth":"","name":"","nationality":""}],"updated":"","version_terms_of_service":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user-company/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "address_main": {\n    "city": "",\n    "country": "",\n    "extra": "",\n    "house_number": "",\n    "is_user_address_updated": false,\n    "mailbox_name": "",\n    "po_box": "",\n    "postal_code": "",\n    "province": "",\n    "street": ""\n  },\n  "address_postal": {},\n  "alias": [\n    {\n      "name": "",\n      "service": "",\n      "type": "",\n      "value": ""\n    }\n  ],\n  "avatar": {\n    "anchor_uuid": "",\n    "image": [\n      {\n        "attachment_public_uuid": "",\n        "content_type": "",\n        "height": 0,\n        "width": 0\n      }\n    ],\n    "style": "",\n    "uuid": ""\n  },\n  "avatar_uuid": "",\n  "billing_contract": [\n    {\n      "contract_date_end": "",\n      "contract_date_start": "",\n      "contract_version": 0,\n      "created": "",\n      "id": 0,\n      "status": "",\n      "sub_status": "",\n      "subscription_type": "",\n      "subscription_type_downgrade": "",\n      "updated": ""\n    }\n  ],\n  "chamber_of_commerce_number": "",\n  "counter_bank_iban": "",\n  "country": "",\n  "created": "",\n  "customer": {\n    "billing_account_id": "",\n    "created": "",\n    "id": 0,\n    "invoice_notification_preference": "",\n    "updated": ""\n  },\n  "customer_limit": {\n    "limit_amount_monthly": {\n      "currency": "",\n      "value": ""\n    },\n    "limit_card_debit_maestro": 0,\n    "limit_card_debit_mastercard": 0,\n    "limit_card_debit_wildcard": 0,\n    "limit_card_replacement": 0,\n    "limit_card_wildcard": 0,\n    "limit_monetary_account": 0,\n    "limit_monetary_account_remaining": 0,\n    "spent_amount_monthly": {}\n  },\n  "daily_limit_without_confirmation_login": {},\n  "deny_reason": "",\n  "directors": [\n    {\n      "avatar": {},\n      "country": "",\n      "display_name": "",\n      "public_nick_name": "",\n      "uuid": ""\n    }\n  ],\n  "display_name": "",\n  "id": 0,\n  "language": "",\n  "legal_form": "",\n  "name": "",\n  "notification_filters": [\n    {\n      "category": "",\n      "notification_delivery_method": "",\n      "notification_target": ""\n    }\n  ],\n  "public_nick_name": "",\n  "public_uuid": "",\n  "region": "",\n  "relations": [\n    {\n      "counter_label_user": {},\n      "counter_user_id": "",\n      "counter_user_status": "",\n      "label_user": {},\n      "relationship": "",\n      "status": "",\n      "user_id": "",\n      "user_status": ""\n    }\n  ],\n  "sector_of_industry": "",\n  "session_timeout": 0,\n  "status": "",\n  "sub_status": "",\n  "tax_resident": [\n    {\n      "country": "",\n      "status": "",\n      "tax_number": ""\n    }\n  ],\n  "type_of_business_entity": "",\n  "ubo": [\n    {\n      "date_of_birth": "",\n      "name": "",\n      "nationality": ""\n    }\n  ],\n  "updated": "",\n  "version_terms_of_service": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"avatar\": {\n    \"anchor_uuid\": \"\",\n    \"image\": [\n      {\n        \"attachment_public_uuid\": \"\",\n        \"content_type\": \"\",\n        \"height\": 0,\n        \"width\": 0\n      }\n    ],\n    \"style\": \"\",\n    \"uuid\": \"\"\n  },\n  \"avatar_uuid\": \"\",\n  \"billing_contract\": [\n    {\n      \"contract_date_end\": \"\",\n      \"contract_date_start\": \"\",\n      \"contract_version\": 0,\n      \"created\": \"\",\n      \"id\": 0,\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"subscription_type\": \"\",\n      \"subscription_type_downgrade\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"chamber_of_commerce_number\": \"\",\n  \"counter_bank_iban\": \"\",\n  \"country\": \"\",\n  \"created\": \"\",\n  \"customer\": {\n    \"billing_account_id\": \"\",\n    \"created\": \"\",\n    \"id\": 0,\n    \"invoice_notification_preference\": \"\",\n    \"updated\": \"\"\n  },\n  \"customer_limit\": {\n    \"limit_amount_monthly\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"limit_card_debit_maestro\": 0,\n    \"limit_card_debit_mastercard\": 0,\n    \"limit_card_debit_wildcard\": 0,\n    \"limit_card_replacement\": 0,\n    \"limit_card_wildcard\": 0,\n    \"limit_monetary_account\": 0,\n    \"limit_monetary_account_remaining\": 0,\n    \"spent_amount_monthly\": {}\n  },\n  \"daily_limit_without_confirmation_login\": {},\n  \"deny_reason\": \"\",\n  \"directors\": [\n    {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    }\n  ],\n  \"display_name\": \"\",\n  \"id\": 0,\n  \"language\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"notification_filters\": [\n    {\n      \"category\": \"\",\n      \"notification_delivery_method\": \"\",\n      \"notification_target\": \"\"\n    }\n  ],\n  \"public_nick_name\": \"\",\n  \"public_uuid\": \"\",\n  \"region\": \"\",\n  \"relations\": [\n    {\n      \"counter_label_user\": {},\n      \"counter_user_id\": \"\",\n      \"counter_user_status\": \"\",\n      \"label_user\": {},\n      \"relationship\": \"\",\n      \"status\": \"\",\n      \"user_id\": \"\",\n      \"user_status\": \"\"\n    }\n  ],\n  \"sector_of_industry\": \"\",\n  \"session_timeout\": 0,\n  \"status\": \"\",\n  \"sub_status\": \"\",\n  \"tax_resident\": [\n    {\n      \"country\": \"\",\n      \"status\": \"\",\n      \"tax_number\": \"\"\n    }\n  ],\n  \"type_of_business_entity\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"updated\": \"\",\n  \"version_terms_of_service\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user-company/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user-company/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  address_main: {
    city: '',
    country: '',
    extra: '',
    house_number: '',
    is_user_address_updated: false,
    mailbox_name: '',
    po_box: '',
    postal_code: '',
    province: '',
    street: ''
  },
  address_postal: {},
  alias: [{name: '', service: '', type: '', value: ''}],
  avatar: {
    anchor_uuid: '',
    image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
    style: '',
    uuid: ''
  },
  avatar_uuid: '',
  billing_contract: [
    {
      contract_date_end: '',
      contract_date_start: '',
      contract_version: 0,
      created: '',
      id: 0,
      status: '',
      sub_status: '',
      subscription_type: '',
      subscription_type_downgrade: '',
      updated: ''
    }
  ],
  chamber_of_commerce_number: '',
  counter_bank_iban: '',
  country: '',
  created: '',
  customer: {
    billing_account_id: '',
    created: '',
    id: 0,
    invoice_notification_preference: '',
    updated: ''
  },
  customer_limit: {
    limit_amount_monthly: {currency: '', value: ''},
    limit_card_debit_maestro: 0,
    limit_card_debit_mastercard: 0,
    limit_card_debit_wildcard: 0,
    limit_card_replacement: 0,
    limit_card_wildcard: 0,
    limit_monetary_account: 0,
    limit_monetary_account_remaining: 0,
    spent_amount_monthly: {}
  },
  daily_limit_without_confirmation_login: {},
  deny_reason: '',
  directors: [{avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''}],
  display_name: '',
  id: 0,
  language: '',
  legal_form: '',
  name: '',
  notification_filters: [{category: '', notification_delivery_method: '', notification_target: ''}],
  public_nick_name: '',
  public_uuid: '',
  region: '',
  relations: [
    {
      counter_label_user: {},
      counter_user_id: '',
      counter_user_status: '',
      label_user: {},
      relationship: '',
      status: '',
      user_id: '',
      user_status: ''
    }
  ],
  sector_of_industry: '',
  session_timeout: 0,
  status: '',
  sub_status: '',
  tax_resident: [{country: '', status: '', tax_number: ''}],
  type_of_business_entity: '',
  ubo: [{date_of_birth: '', name: '', nationality: ''}],
  updated: '',
  version_terms_of_service: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user-company/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    address_main: {
      city: '',
      country: '',
      extra: '',
      house_number: '',
      is_user_address_updated: false,
      mailbox_name: '',
      po_box: '',
      postal_code: '',
      province: '',
      street: ''
    },
    address_postal: {},
    alias: [{name: '', service: '', type: '', value: ''}],
    avatar: {
      anchor_uuid: '',
      image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
      style: '',
      uuid: ''
    },
    avatar_uuid: '',
    billing_contract: [
      {
        contract_date_end: '',
        contract_date_start: '',
        contract_version: 0,
        created: '',
        id: 0,
        status: '',
        sub_status: '',
        subscription_type: '',
        subscription_type_downgrade: '',
        updated: ''
      }
    ],
    chamber_of_commerce_number: '',
    counter_bank_iban: '',
    country: '',
    created: '',
    customer: {
      billing_account_id: '',
      created: '',
      id: 0,
      invoice_notification_preference: '',
      updated: ''
    },
    customer_limit: {
      limit_amount_monthly: {currency: '', value: ''},
      limit_card_debit_maestro: 0,
      limit_card_debit_mastercard: 0,
      limit_card_debit_wildcard: 0,
      limit_card_replacement: 0,
      limit_card_wildcard: 0,
      limit_monetary_account: 0,
      limit_monetary_account_remaining: 0,
      spent_amount_monthly: {}
    },
    daily_limit_without_confirmation_login: {},
    deny_reason: '',
    directors: [{avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''}],
    display_name: '',
    id: 0,
    language: '',
    legal_form: '',
    name: '',
    notification_filters: [{category: '', notification_delivery_method: '', notification_target: ''}],
    public_nick_name: '',
    public_uuid: '',
    region: '',
    relations: [
      {
        counter_label_user: {},
        counter_user_id: '',
        counter_user_status: '',
        label_user: {},
        relationship: '',
        status: '',
        user_id: '',
        user_status: ''
      }
    ],
    sector_of_industry: '',
    session_timeout: 0,
    status: '',
    sub_status: '',
    tax_resident: [{country: '', status: '', tax_number: ''}],
    type_of_business_entity: '',
    ubo: [{date_of_birth: '', name: '', nationality: ''}],
    updated: '',
    version_terms_of_service: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user-company/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  address_main: {
    city: '',
    country: '',
    extra: '',
    house_number: '',
    is_user_address_updated: false,
    mailbox_name: '',
    po_box: '',
    postal_code: '',
    province: '',
    street: ''
  },
  address_postal: {},
  alias: [
    {
      name: '',
      service: '',
      type: '',
      value: ''
    }
  ],
  avatar: {
    anchor_uuid: '',
    image: [
      {
        attachment_public_uuid: '',
        content_type: '',
        height: 0,
        width: 0
      }
    ],
    style: '',
    uuid: ''
  },
  avatar_uuid: '',
  billing_contract: [
    {
      contract_date_end: '',
      contract_date_start: '',
      contract_version: 0,
      created: '',
      id: 0,
      status: '',
      sub_status: '',
      subscription_type: '',
      subscription_type_downgrade: '',
      updated: ''
    }
  ],
  chamber_of_commerce_number: '',
  counter_bank_iban: '',
  country: '',
  created: '',
  customer: {
    billing_account_id: '',
    created: '',
    id: 0,
    invoice_notification_preference: '',
    updated: ''
  },
  customer_limit: {
    limit_amount_monthly: {
      currency: '',
      value: ''
    },
    limit_card_debit_maestro: 0,
    limit_card_debit_mastercard: 0,
    limit_card_debit_wildcard: 0,
    limit_card_replacement: 0,
    limit_card_wildcard: 0,
    limit_monetary_account: 0,
    limit_monetary_account_remaining: 0,
    spent_amount_monthly: {}
  },
  daily_limit_without_confirmation_login: {},
  deny_reason: '',
  directors: [
    {
      avatar: {},
      country: '',
      display_name: '',
      public_nick_name: '',
      uuid: ''
    }
  ],
  display_name: '',
  id: 0,
  language: '',
  legal_form: '',
  name: '',
  notification_filters: [
    {
      category: '',
      notification_delivery_method: '',
      notification_target: ''
    }
  ],
  public_nick_name: '',
  public_uuid: '',
  region: '',
  relations: [
    {
      counter_label_user: {},
      counter_user_id: '',
      counter_user_status: '',
      label_user: {},
      relationship: '',
      status: '',
      user_id: '',
      user_status: ''
    }
  ],
  sector_of_industry: '',
  session_timeout: 0,
  status: '',
  sub_status: '',
  tax_resident: [
    {
      country: '',
      status: '',
      tax_number: ''
    }
  ],
  type_of_business_entity: '',
  ubo: [
    {
      date_of_birth: '',
      name: '',
      nationality: ''
    }
  ],
  updated: '',
  version_terms_of_service: ''
});

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}}/user-company/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    address_main: {
      city: '',
      country: '',
      extra: '',
      house_number: '',
      is_user_address_updated: false,
      mailbox_name: '',
      po_box: '',
      postal_code: '',
      province: '',
      street: ''
    },
    address_postal: {},
    alias: [{name: '', service: '', type: '', value: ''}],
    avatar: {
      anchor_uuid: '',
      image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
      style: '',
      uuid: ''
    },
    avatar_uuid: '',
    billing_contract: [
      {
        contract_date_end: '',
        contract_date_start: '',
        contract_version: 0,
        created: '',
        id: 0,
        status: '',
        sub_status: '',
        subscription_type: '',
        subscription_type_downgrade: '',
        updated: ''
      }
    ],
    chamber_of_commerce_number: '',
    counter_bank_iban: '',
    country: '',
    created: '',
    customer: {
      billing_account_id: '',
      created: '',
      id: 0,
      invoice_notification_preference: '',
      updated: ''
    },
    customer_limit: {
      limit_amount_monthly: {currency: '', value: ''},
      limit_card_debit_maestro: 0,
      limit_card_debit_mastercard: 0,
      limit_card_debit_wildcard: 0,
      limit_card_replacement: 0,
      limit_card_wildcard: 0,
      limit_monetary_account: 0,
      limit_monetary_account_remaining: 0,
      spent_amount_monthly: {}
    },
    daily_limit_without_confirmation_login: {},
    deny_reason: '',
    directors: [{avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''}],
    display_name: '',
    id: 0,
    language: '',
    legal_form: '',
    name: '',
    notification_filters: [{category: '', notification_delivery_method: '', notification_target: ''}],
    public_nick_name: '',
    public_uuid: '',
    region: '',
    relations: [
      {
        counter_label_user: {},
        counter_user_id: '',
        counter_user_status: '',
        label_user: {},
        relationship: '',
        status: '',
        user_id: '',
        user_status: ''
      }
    ],
    sector_of_industry: '',
    session_timeout: 0,
    status: '',
    sub_status: '',
    tax_resident: [{country: '', status: '', tax_number: ''}],
    type_of_business_entity: '',
    ubo: [{date_of_birth: '', name: '', nationality: ''}],
    updated: '',
    version_terms_of_service: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user-company/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"address_main":{"city":"","country":"","extra":"","house_number":"","is_user_address_updated":false,"mailbox_name":"","po_box":"","postal_code":"","province":"","street":""},"address_postal":{},"alias":[{"name":"","service":"","type":"","value":""}],"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"avatar_uuid":"","billing_contract":[{"contract_date_end":"","contract_date_start":"","contract_version":0,"created":"","id":0,"status":"","sub_status":"","subscription_type":"","subscription_type_downgrade":"","updated":""}],"chamber_of_commerce_number":"","counter_bank_iban":"","country":"","created":"","customer":{"billing_account_id":"","created":"","id":0,"invoice_notification_preference":"","updated":""},"customer_limit":{"limit_amount_monthly":{"currency":"","value":""},"limit_card_debit_maestro":0,"limit_card_debit_mastercard":0,"limit_card_debit_wildcard":0,"limit_card_replacement":0,"limit_card_wildcard":0,"limit_monetary_account":0,"limit_monetary_account_remaining":0,"spent_amount_monthly":{}},"daily_limit_without_confirmation_login":{},"deny_reason":"","directors":[{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""}],"display_name":"","id":0,"language":"","legal_form":"","name":"","notification_filters":[{"category":"","notification_delivery_method":"","notification_target":""}],"public_nick_name":"","public_uuid":"","region":"","relations":[{"counter_label_user":{},"counter_user_id":"","counter_user_status":"","label_user":{},"relationship":"","status":"","user_id":"","user_status":""}],"sector_of_industry":"","session_timeout":0,"status":"","sub_status":"","tax_resident":[{"country":"","status":"","tax_number":""}],"type_of_business_entity":"","ubo":[{"date_of_birth":"","name":"","nationality":""}],"updated":"","version_terms_of_service":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"address_main": @{ @"city": @"", @"country": @"", @"extra": @"", @"house_number": @"", @"is_user_address_updated": @NO, @"mailbox_name": @"", @"po_box": @"", @"postal_code": @"", @"province": @"", @"street": @"" },
                              @"address_postal": @{  },
                              @"alias": @[ @{ @"name": @"", @"service": @"", @"type": @"", @"value": @"" } ],
                              @"avatar": @{ @"anchor_uuid": @"", @"image": @[ @{ @"attachment_public_uuid": @"", @"content_type": @"", @"height": @0, @"width": @0 } ], @"style": @"", @"uuid": @"" },
                              @"avatar_uuid": @"",
                              @"billing_contract": @[ @{ @"contract_date_end": @"", @"contract_date_start": @"", @"contract_version": @0, @"created": @"", @"id": @0, @"status": @"", @"sub_status": @"", @"subscription_type": @"", @"subscription_type_downgrade": @"", @"updated": @"" } ],
                              @"chamber_of_commerce_number": @"",
                              @"counter_bank_iban": @"",
                              @"country": @"",
                              @"created": @"",
                              @"customer": @{ @"billing_account_id": @"", @"created": @"", @"id": @0, @"invoice_notification_preference": @"", @"updated": @"" },
                              @"customer_limit": @{ @"limit_amount_monthly": @{ @"currency": @"", @"value": @"" }, @"limit_card_debit_maestro": @0, @"limit_card_debit_mastercard": @0, @"limit_card_debit_wildcard": @0, @"limit_card_replacement": @0, @"limit_card_wildcard": @0, @"limit_monetary_account": @0, @"limit_monetary_account_remaining": @0, @"spent_amount_monthly": @{  } },
                              @"daily_limit_without_confirmation_login": @{  },
                              @"deny_reason": @"",
                              @"directors": @[ @{ @"avatar": @{  }, @"country": @"", @"display_name": @"", @"public_nick_name": @"", @"uuid": @"" } ],
                              @"display_name": @"",
                              @"id": @0,
                              @"language": @"",
                              @"legal_form": @"",
                              @"name": @"",
                              @"notification_filters": @[ @{ @"category": @"", @"notification_delivery_method": @"", @"notification_target": @"" } ],
                              @"public_nick_name": @"",
                              @"public_uuid": @"",
                              @"region": @"",
                              @"relations": @[ @{ @"counter_label_user": @{  }, @"counter_user_id": @"", @"counter_user_status": @"", @"label_user": @{  }, @"relationship": @"", @"status": @"", @"user_id": @"", @"user_status": @"" } ],
                              @"sector_of_industry": @"",
                              @"session_timeout": @0,
                              @"status": @"",
                              @"sub_status": @"",
                              @"tax_resident": @[ @{ @"country": @"", @"status": @"", @"tax_number": @"" } ],
                              @"type_of_business_entity": @"",
                              @"ubo": @[ @{ @"date_of_birth": @"", @"name": @"", @"nationality": @"" } ],
                              @"updated": @"",
                              @"version_terms_of_service": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user-company/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user-company/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"avatar\": {\n    \"anchor_uuid\": \"\",\n    \"image\": [\n      {\n        \"attachment_public_uuid\": \"\",\n        \"content_type\": \"\",\n        \"height\": 0,\n        \"width\": 0\n      }\n    ],\n    \"style\": \"\",\n    \"uuid\": \"\"\n  },\n  \"avatar_uuid\": \"\",\n  \"billing_contract\": [\n    {\n      \"contract_date_end\": \"\",\n      \"contract_date_start\": \"\",\n      \"contract_version\": 0,\n      \"created\": \"\",\n      \"id\": 0,\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"subscription_type\": \"\",\n      \"subscription_type_downgrade\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"chamber_of_commerce_number\": \"\",\n  \"counter_bank_iban\": \"\",\n  \"country\": \"\",\n  \"created\": \"\",\n  \"customer\": {\n    \"billing_account_id\": \"\",\n    \"created\": \"\",\n    \"id\": 0,\n    \"invoice_notification_preference\": \"\",\n    \"updated\": \"\"\n  },\n  \"customer_limit\": {\n    \"limit_amount_monthly\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"limit_card_debit_maestro\": 0,\n    \"limit_card_debit_mastercard\": 0,\n    \"limit_card_debit_wildcard\": 0,\n    \"limit_card_replacement\": 0,\n    \"limit_card_wildcard\": 0,\n    \"limit_monetary_account\": 0,\n    \"limit_monetary_account_remaining\": 0,\n    \"spent_amount_monthly\": {}\n  },\n  \"daily_limit_without_confirmation_login\": {},\n  \"deny_reason\": \"\",\n  \"directors\": [\n    {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    }\n  ],\n  \"display_name\": \"\",\n  \"id\": 0,\n  \"language\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"notification_filters\": [\n    {\n      \"category\": \"\",\n      \"notification_delivery_method\": \"\",\n      \"notification_target\": \"\"\n    }\n  ],\n  \"public_nick_name\": \"\",\n  \"public_uuid\": \"\",\n  \"region\": \"\",\n  \"relations\": [\n    {\n      \"counter_label_user\": {},\n      \"counter_user_id\": \"\",\n      \"counter_user_status\": \"\",\n      \"label_user\": {},\n      \"relationship\": \"\",\n      \"status\": \"\",\n      \"user_id\": \"\",\n      \"user_status\": \"\"\n    }\n  ],\n  \"sector_of_industry\": \"\",\n  \"session_timeout\": 0,\n  \"status\": \"\",\n  \"sub_status\": \"\",\n  \"tax_resident\": [\n    {\n      \"country\": \"\",\n      \"status\": \"\",\n      \"tax_number\": \"\"\n    }\n  ],\n  \"type_of_business_entity\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"updated\": \"\",\n  \"version_terms_of_service\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user-company/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'address_main' => [
        'city' => '',
        'country' => '',
        'extra' => '',
        'house_number' => '',
        'is_user_address_updated' => null,
        'mailbox_name' => '',
        'po_box' => '',
        'postal_code' => '',
        'province' => '',
        'street' => ''
    ],
    'address_postal' => [
        
    ],
    'alias' => [
        [
                'name' => '',
                'service' => '',
                'type' => '',
                'value' => ''
        ]
    ],
    'avatar' => [
        'anchor_uuid' => '',
        'image' => [
                [
                                'attachment_public_uuid' => '',
                                'content_type' => '',
                                'height' => 0,
                                'width' => 0
                ]
        ],
        'style' => '',
        'uuid' => ''
    ],
    'avatar_uuid' => '',
    'billing_contract' => [
        [
                'contract_date_end' => '',
                'contract_date_start' => '',
                'contract_version' => 0,
                'created' => '',
                'id' => 0,
                'status' => '',
                'sub_status' => '',
                'subscription_type' => '',
                'subscription_type_downgrade' => '',
                'updated' => ''
        ]
    ],
    'chamber_of_commerce_number' => '',
    'counter_bank_iban' => '',
    'country' => '',
    'created' => '',
    'customer' => [
        'billing_account_id' => '',
        'created' => '',
        'id' => 0,
        'invoice_notification_preference' => '',
        'updated' => ''
    ],
    'customer_limit' => [
        'limit_amount_monthly' => [
                'currency' => '',
                'value' => ''
        ],
        'limit_card_debit_maestro' => 0,
        'limit_card_debit_mastercard' => 0,
        'limit_card_debit_wildcard' => 0,
        'limit_card_replacement' => 0,
        'limit_card_wildcard' => 0,
        'limit_monetary_account' => 0,
        'limit_monetary_account_remaining' => 0,
        'spent_amount_monthly' => [
                
        ]
    ],
    'daily_limit_without_confirmation_login' => [
        
    ],
    'deny_reason' => '',
    'directors' => [
        [
                'avatar' => [
                                
                ],
                'country' => '',
                'display_name' => '',
                'public_nick_name' => '',
                'uuid' => ''
        ]
    ],
    'display_name' => '',
    'id' => 0,
    'language' => '',
    'legal_form' => '',
    'name' => '',
    'notification_filters' => [
        [
                'category' => '',
                'notification_delivery_method' => '',
                'notification_target' => ''
        ]
    ],
    'public_nick_name' => '',
    'public_uuid' => '',
    'region' => '',
    'relations' => [
        [
                'counter_label_user' => [
                                
                ],
                'counter_user_id' => '',
                'counter_user_status' => '',
                'label_user' => [
                                
                ],
                'relationship' => '',
                'status' => '',
                'user_id' => '',
                'user_status' => ''
        ]
    ],
    'sector_of_industry' => '',
    'session_timeout' => 0,
    'status' => '',
    'sub_status' => '',
    'tax_resident' => [
        [
                'country' => '',
                'status' => '',
                'tax_number' => ''
        ]
    ],
    'type_of_business_entity' => '',
    'ubo' => [
        [
                'date_of_birth' => '',
                'name' => '',
                'nationality' => ''
        ]
    ],
    'updated' => '',
    'version_terms_of_service' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user-company/:itemId', [
  'body' => '{
  "address_main": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_postal": {},
  "alias": [
    {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    }
  ],
  "avatar": {
    "anchor_uuid": "",
    "image": [
      {
        "attachment_public_uuid": "",
        "content_type": "",
        "height": 0,
        "width": 0
      }
    ],
    "style": "",
    "uuid": ""
  },
  "avatar_uuid": "",
  "billing_contract": [
    {
      "contract_date_end": "",
      "contract_date_start": "",
      "contract_version": 0,
      "created": "",
      "id": 0,
      "status": "",
      "sub_status": "",
      "subscription_type": "",
      "subscription_type_downgrade": "",
      "updated": ""
    }
  ],
  "chamber_of_commerce_number": "",
  "counter_bank_iban": "",
  "country": "",
  "created": "",
  "customer": {
    "billing_account_id": "",
    "created": "",
    "id": 0,
    "invoice_notification_preference": "",
    "updated": ""
  },
  "customer_limit": {
    "limit_amount_monthly": {
      "currency": "",
      "value": ""
    },
    "limit_card_debit_maestro": 0,
    "limit_card_debit_mastercard": 0,
    "limit_card_debit_wildcard": 0,
    "limit_card_replacement": 0,
    "limit_card_wildcard": 0,
    "limit_monetary_account": 0,
    "limit_monetary_account_remaining": 0,
    "spent_amount_monthly": {}
  },
  "daily_limit_without_confirmation_login": {},
  "deny_reason": "",
  "directors": [
    {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    }
  ],
  "display_name": "",
  "id": 0,
  "language": "",
  "legal_form": "",
  "name": "",
  "notification_filters": [
    {
      "category": "",
      "notification_delivery_method": "",
      "notification_target": ""
    }
  ],
  "public_nick_name": "",
  "public_uuid": "",
  "region": "",
  "relations": [
    {
      "counter_label_user": {},
      "counter_user_id": "",
      "counter_user_status": "",
      "label_user": {},
      "relationship": "",
      "status": "",
      "user_id": "",
      "user_status": ""
    }
  ],
  "sector_of_industry": "",
  "session_timeout": 0,
  "status": "",
  "sub_status": "",
  "tax_resident": [
    {
      "country": "",
      "status": "",
      "tax_number": ""
    }
  ],
  "type_of_business_entity": "",
  "ubo": [
    {
      "date_of_birth": "",
      "name": "",
      "nationality": ""
    }
  ],
  "updated": "",
  "version_terms_of_service": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user-company/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'address_main' => [
    'city' => '',
    'country' => '',
    'extra' => '',
    'house_number' => '',
    'is_user_address_updated' => null,
    'mailbox_name' => '',
    'po_box' => '',
    'postal_code' => '',
    'province' => '',
    'street' => ''
  ],
  'address_postal' => [
    
  ],
  'alias' => [
    [
        'name' => '',
        'service' => '',
        'type' => '',
        'value' => ''
    ]
  ],
  'avatar' => [
    'anchor_uuid' => '',
    'image' => [
        [
                'attachment_public_uuid' => '',
                'content_type' => '',
                'height' => 0,
                'width' => 0
        ]
    ],
    'style' => '',
    'uuid' => ''
  ],
  'avatar_uuid' => '',
  'billing_contract' => [
    [
        'contract_date_end' => '',
        'contract_date_start' => '',
        'contract_version' => 0,
        'created' => '',
        'id' => 0,
        'status' => '',
        'sub_status' => '',
        'subscription_type' => '',
        'subscription_type_downgrade' => '',
        'updated' => ''
    ]
  ],
  'chamber_of_commerce_number' => '',
  'counter_bank_iban' => '',
  'country' => '',
  'created' => '',
  'customer' => [
    'billing_account_id' => '',
    'created' => '',
    'id' => 0,
    'invoice_notification_preference' => '',
    'updated' => ''
  ],
  'customer_limit' => [
    'limit_amount_monthly' => [
        'currency' => '',
        'value' => ''
    ],
    'limit_card_debit_maestro' => 0,
    'limit_card_debit_mastercard' => 0,
    'limit_card_debit_wildcard' => 0,
    'limit_card_replacement' => 0,
    'limit_card_wildcard' => 0,
    'limit_monetary_account' => 0,
    'limit_monetary_account_remaining' => 0,
    'spent_amount_monthly' => [
        
    ]
  ],
  'daily_limit_without_confirmation_login' => [
    
  ],
  'deny_reason' => '',
  'directors' => [
    [
        'avatar' => [
                
        ],
        'country' => '',
        'display_name' => '',
        'public_nick_name' => '',
        'uuid' => ''
    ]
  ],
  'display_name' => '',
  'id' => 0,
  'language' => '',
  'legal_form' => '',
  'name' => '',
  'notification_filters' => [
    [
        'category' => '',
        'notification_delivery_method' => '',
        'notification_target' => ''
    ]
  ],
  'public_nick_name' => '',
  'public_uuid' => '',
  'region' => '',
  'relations' => [
    [
        'counter_label_user' => [
                
        ],
        'counter_user_id' => '',
        'counter_user_status' => '',
        'label_user' => [
                
        ],
        'relationship' => '',
        'status' => '',
        'user_id' => '',
        'user_status' => ''
    ]
  ],
  'sector_of_industry' => '',
  'session_timeout' => 0,
  'status' => '',
  'sub_status' => '',
  'tax_resident' => [
    [
        'country' => '',
        'status' => '',
        'tax_number' => ''
    ]
  ],
  'type_of_business_entity' => '',
  'ubo' => [
    [
        'date_of_birth' => '',
        'name' => '',
        'nationality' => ''
    ]
  ],
  'updated' => '',
  'version_terms_of_service' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'address_main' => [
    'city' => '',
    'country' => '',
    'extra' => '',
    'house_number' => '',
    'is_user_address_updated' => null,
    'mailbox_name' => '',
    'po_box' => '',
    'postal_code' => '',
    'province' => '',
    'street' => ''
  ],
  'address_postal' => [
    
  ],
  'alias' => [
    [
        'name' => '',
        'service' => '',
        'type' => '',
        'value' => ''
    ]
  ],
  'avatar' => [
    'anchor_uuid' => '',
    'image' => [
        [
                'attachment_public_uuid' => '',
                'content_type' => '',
                'height' => 0,
                'width' => 0
        ]
    ],
    'style' => '',
    'uuid' => ''
  ],
  'avatar_uuid' => '',
  'billing_contract' => [
    [
        'contract_date_end' => '',
        'contract_date_start' => '',
        'contract_version' => 0,
        'created' => '',
        'id' => 0,
        'status' => '',
        'sub_status' => '',
        'subscription_type' => '',
        'subscription_type_downgrade' => '',
        'updated' => ''
    ]
  ],
  'chamber_of_commerce_number' => '',
  'counter_bank_iban' => '',
  'country' => '',
  'created' => '',
  'customer' => [
    'billing_account_id' => '',
    'created' => '',
    'id' => 0,
    'invoice_notification_preference' => '',
    'updated' => ''
  ],
  'customer_limit' => [
    'limit_amount_monthly' => [
        'currency' => '',
        'value' => ''
    ],
    'limit_card_debit_maestro' => 0,
    'limit_card_debit_mastercard' => 0,
    'limit_card_debit_wildcard' => 0,
    'limit_card_replacement' => 0,
    'limit_card_wildcard' => 0,
    'limit_monetary_account' => 0,
    'limit_monetary_account_remaining' => 0,
    'spent_amount_monthly' => [
        
    ]
  ],
  'daily_limit_without_confirmation_login' => [
    
  ],
  'deny_reason' => '',
  'directors' => [
    [
        'avatar' => [
                
        ],
        'country' => '',
        'display_name' => '',
        'public_nick_name' => '',
        'uuid' => ''
    ]
  ],
  'display_name' => '',
  'id' => 0,
  'language' => '',
  'legal_form' => '',
  'name' => '',
  'notification_filters' => [
    [
        'category' => '',
        'notification_delivery_method' => '',
        'notification_target' => ''
    ]
  ],
  'public_nick_name' => '',
  'public_uuid' => '',
  'region' => '',
  'relations' => [
    [
        'counter_label_user' => [
                
        ],
        'counter_user_id' => '',
        'counter_user_status' => '',
        'label_user' => [
                
        ],
        'relationship' => '',
        'status' => '',
        'user_id' => '',
        'user_status' => ''
    ]
  ],
  'sector_of_industry' => '',
  'session_timeout' => 0,
  'status' => '',
  'sub_status' => '',
  'tax_resident' => [
    [
        'country' => '',
        'status' => '',
        'tax_number' => ''
    ]
  ],
  'type_of_business_entity' => '',
  'ubo' => [
    [
        'date_of_birth' => '',
        'name' => '',
        'nationality' => ''
    ]
  ],
  'updated' => '',
  'version_terms_of_service' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user-company/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user-company/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "address_main": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_postal": {},
  "alias": [
    {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    }
  ],
  "avatar": {
    "anchor_uuid": "",
    "image": [
      {
        "attachment_public_uuid": "",
        "content_type": "",
        "height": 0,
        "width": 0
      }
    ],
    "style": "",
    "uuid": ""
  },
  "avatar_uuid": "",
  "billing_contract": [
    {
      "contract_date_end": "",
      "contract_date_start": "",
      "contract_version": 0,
      "created": "",
      "id": 0,
      "status": "",
      "sub_status": "",
      "subscription_type": "",
      "subscription_type_downgrade": "",
      "updated": ""
    }
  ],
  "chamber_of_commerce_number": "",
  "counter_bank_iban": "",
  "country": "",
  "created": "",
  "customer": {
    "billing_account_id": "",
    "created": "",
    "id": 0,
    "invoice_notification_preference": "",
    "updated": ""
  },
  "customer_limit": {
    "limit_amount_monthly": {
      "currency": "",
      "value": ""
    },
    "limit_card_debit_maestro": 0,
    "limit_card_debit_mastercard": 0,
    "limit_card_debit_wildcard": 0,
    "limit_card_replacement": 0,
    "limit_card_wildcard": 0,
    "limit_monetary_account": 0,
    "limit_monetary_account_remaining": 0,
    "spent_amount_monthly": {}
  },
  "daily_limit_without_confirmation_login": {},
  "deny_reason": "",
  "directors": [
    {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    }
  ],
  "display_name": "",
  "id": 0,
  "language": "",
  "legal_form": "",
  "name": "",
  "notification_filters": [
    {
      "category": "",
      "notification_delivery_method": "",
      "notification_target": ""
    }
  ],
  "public_nick_name": "",
  "public_uuid": "",
  "region": "",
  "relations": [
    {
      "counter_label_user": {},
      "counter_user_id": "",
      "counter_user_status": "",
      "label_user": {},
      "relationship": "",
      "status": "",
      "user_id": "",
      "user_status": ""
    }
  ],
  "sector_of_industry": "",
  "session_timeout": 0,
  "status": "",
  "sub_status": "",
  "tax_resident": [
    {
      "country": "",
      "status": "",
      "tax_number": ""
    }
  ],
  "type_of_business_entity": "",
  "ubo": [
    {
      "date_of_birth": "",
      "name": "",
      "nationality": ""
    }
  ],
  "updated": "",
  "version_terms_of_service": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user-company/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "address_main": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_postal": {},
  "alias": [
    {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    }
  ],
  "avatar": {
    "anchor_uuid": "",
    "image": [
      {
        "attachment_public_uuid": "",
        "content_type": "",
        "height": 0,
        "width": 0
      }
    ],
    "style": "",
    "uuid": ""
  },
  "avatar_uuid": "",
  "billing_contract": [
    {
      "contract_date_end": "",
      "contract_date_start": "",
      "contract_version": 0,
      "created": "",
      "id": 0,
      "status": "",
      "sub_status": "",
      "subscription_type": "",
      "subscription_type_downgrade": "",
      "updated": ""
    }
  ],
  "chamber_of_commerce_number": "",
  "counter_bank_iban": "",
  "country": "",
  "created": "",
  "customer": {
    "billing_account_id": "",
    "created": "",
    "id": 0,
    "invoice_notification_preference": "",
    "updated": ""
  },
  "customer_limit": {
    "limit_amount_monthly": {
      "currency": "",
      "value": ""
    },
    "limit_card_debit_maestro": 0,
    "limit_card_debit_mastercard": 0,
    "limit_card_debit_wildcard": 0,
    "limit_card_replacement": 0,
    "limit_card_wildcard": 0,
    "limit_monetary_account": 0,
    "limit_monetary_account_remaining": 0,
    "spent_amount_monthly": {}
  },
  "daily_limit_without_confirmation_login": {},
  "deny_reason": "",
  "directors": [
    {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    }
  ],
  "display_name": "",
  "id": 0,
  "language": "",
  "legal_form": "",
  "name": "",
  "notification_filters": [
    {
      "category": "",
      "notification_delivery_method": "",
      "notification_target": ""
    }
  ],
  "public_nick_name": "",
  "public_uuid": "",
  "region": "",
  "relations": [
    {
      "counter_label_user": {},
      "counter_user_id": "",
      "counter_user_status": "",
      "label_user": {},
      "relationship": "",
      "status": "",
      "user_id": "",
      "user_status": ""
    }
  ],
  "sector_of_industry": "",
  "session_timeout": 0,
  "status": "",
  "sub_status": "",
  "tax_resident": [
    {
      "country": "",
      "status": "",
      "tax_number": ""
    }
  ],
  "type_of_business_entity": "",
  "ubo": [
    {
      "date_of_birth": "",
      "name": "",
      "nationality": ""
    }
  ],
  "updated": "",
  "version_terms_of_service": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"avatar\": {\n    \"anchor_uuid\": \"\",\n    \"image\": [\n      {\n        \"attachment_public_uuid\": \"\",\n        \"content_type\": \"\",\n        \"height\": 0,\n        \"width\": 0\n      }\n    ],\n    \"style\": \"\",\n    \"uuid\": \"\"\n  },\n  \"avatar_uuid\": \"\",\n  \"billing_contract\": [\n    {\n      \"contract_date_end\": \"\",\n      \"contract_date_start\": \"\",\n      \"contract_version\": 0,\n      \"created\": \"\",\n      \"id\": 0,\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"subscription_type\": \"\",\n      \"subscription_type_downgrade\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"chamber_of_commerce_number\": \"\",\n  \"counter_bank_iban\": \"\",\n  \"country\": \"\",\n  \"created\": \"\",\n  \"customer\": {\n    \"billing_account_id\": \"\",\n    \"created\": \"\",\n    \"id\": 0,\n    \"invoice_notification_preference\": \"\",\n    \"updated\": \"\"\n  },\n  \"customer_limit\": {\n    \"limit_amount_monthly\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"limit_card_debit_maestro\": 0,\n    \"limit_card_debit_mastercard\": 0,\n    \"limit_card_debit_wildcard\": 0,\n    \"limit_card_replacement\": 0,\n    \"limit_card_wildcard\": 0,\n    \"limit_monetary_account\": 0,\n    \"limit_monetary_account_remaining\": 0,\n    \"spent_amount_monthly\": {}\n  },\n  \"daily_limit_without_confirmation_login\": {},\n  \"deny_reason\": \"\",\n  \"directors\": [\n    {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    }\n  ],\n  \"display_name\": \"\",\n  \"id\": 0,\n  \"language\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"notification_filters\": [\n    {\n      \"category\": \"\",\n      \"notification_delivery_method\": \"\",\n      \"notification_target\": \"\"\n    }\n  ],\n  \"public_nick_name\": \"\",\n  \"public_uuid\": \"\",\n  \"region\": \"\",\n  \"relations\": [\n    {\n      \"counter_label_user\": {},\n      \"counter_user_id\": \"\",\n      \"counter_user_status\": \"\",\n      \"label_user\": {},\n      \"relationship\": \"\",\n      \"status\": \"\",\n      \"user_id\": \"\",\n      \"user_status\": \"\"\n    }\n  ],\n  \"sector_of_industry\": \"\",\n  \"session_timeout\": 0,\n  \"status\": \"\",\n  \"sub_status\": \"\",\n  \"tax_resident\": [\n    {\n      \"country\": \"\",\n      \"status\": \"\",\n      \"tax_number\": \"\"\n    }\n  ],\n  \"type_of_business_entity\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"updated\": \"\",\n  \"version_terms_of_service\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user-company/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user-company/:itemId"

payload = {
    "address_main": {
        "city": "",
        "country": "",
        "extra": "",
        "house_number": "",
        "is_user_address_updated": False,
        "mailbox_name": "",
        "po_box": "",
        "postal_code": "",
        "province": "",
        "street": ""
    },
    "address_postal": {},
    "alias": [
        {
            "name": "",
            "service": "",
            "type": "",
            "value": ""
        }
    ],
    "avatar": {
        "anchor_uuid": "",
        "image": [
            {
                "attachment_public_uuid": "",
                "content_type": "",
                "height": 0,
                "width": 0
            }
        ],
        "style": "",
        "uuid": ""
    },
    "avatar_uuid": "",
    "billing_contract": [
        {
            "contract_date_end": "",
            "contract_date_start": "",
            "contract_version": 0,
            "created": "",
            "id": 0,
            "status": "",
            "sub_status": "",
            "subscription_type": "",
            "subscription_type_downgrade": "",
            "updated": ""
        }
    ],
    "chamber_of_commerce_number": "",
    "counter_bank_iban": "",
    "country": "",
    "created": "",
    "customer": {
        "billing_account_id": "",
        "created": "",
        "id": 0,
        "invoice_notification_preference": "",
        "updated": ""
    },
    "customer_limit": {
        "limit_amount_monthly": {
            "currency": "",
            "value": ""
        },
        "limit_card_debit_maestro": 0,
        "limit_card_debit_mastercard": 0,
        "limit_card_debit_wildcard": 0,
        "limit_card_replacement": 0,
        "limit_card_wildcard": 0,
        "limit_monetary_account": 0,
        "limit_monetary_account_remaining": 0,
        "spent_amount_monthly": {}
    },
    "daily_limit_without_confirmation_login": {},
    "deny_reason": "",
    "directors": [
        {
            "avatar": {},
            "country": "",
            "display_name": "",
            "public_nick_name": "",
            "uuid": ""
        }
    ],
    "display_name": "",
    "id": 0,
    "language": "",
    "legal_form": "",
    "name": "",
    "notification_filters": [
        {
            "category": "",
            "notification_delivery_method": "",
            "notification_target": ""
        }
    ],
    "public_nick_name": "",
    "public_uuid": "",
    "region": "",
    "relations": [
        {
            "counter_label_user": {},
            "counter_user_id": "",
            "counter_user_status": "",
            "label_user": {},
            "relationship": "",
            "status": "",
            "user_id": "",
            "user_status": ""
        }
    ],
    "sector_of_industry": "",
    "session_timeout": 0,
    "status": "",
    "sub_status": "",
    "tax_resident": [
        {
            "country": "",
            "status": "",
            "tax_number": ""
        }
    ],
    "type_of_business_entity": "",
    "ubo": [
        {
            "date_of_birth": "",
            "name": "",
            "nationality": ""
        }
    ],
    "updated": "",
    "version_terms_of_service": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user-company/:itemId"

payload <- "{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"avatar\": {\n    \"anchor_uuid\": \"\",\n    \"image\": [\n      {\n        \"attachment_public_uuid\": \"\",\n        \"content_type\": \"\",\n        \"height\": 0,\n        \"width\": 0\n      }\n    ],\n    \"style\": \"\",\n    \"uuid\": \"\"\n  },\n  \"avatar_uuid\": \"\",\n  \"billing_contract\": [\n    {\n      \"contract_date_end\": \"\",\n      \"contract_date_start\": \"\",\n      \"contract_version\": 0,\n      \"created\": \"\",\n      \"id\": 0,\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"subscription_type\": \"\",\n      \"subscription_type_downgrade\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"chamber_of_commerce_number\": \"\",\n  \"counter_bank_iban\": \"\",\n  \"country\": \"\",\n  \"created\": \"\",\n  \"customer\": {\n    \"billing_account_id\": \"\",\n    \"created\": \"\",\n    \"id\": 0,\n    \"invoice_notification_preference\": \"\",\n    \"updated\": \"\"\n  },\n  \"customer_limit\": {\n    \"limit_amount_monthly\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"limit_card_debit_maestro\": 0,\n    \"limit_card_debit_mastercard\": 0,\n    \"limit_card_debit_wildcard\": 0,\n    \"limit_card_replacement\": 0,\n    \"limit_card_wildcard\": 0,\n    \"limit_monetary_account\": 0,\n    \"limit_monetary_account_remaining\": 0,\n    \"spent_amount_monthly\": {}\n  },\n  \"daily_limit_without_confirmation_login\": {},\n  \"deny_reason\": \"\",\n  \"directors\": [\n    {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    }\n  ],\n  \"display_name\": \"\",\n  \"id\": 0,\n  \"language\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"notification_filters\": [\n    {\n      \"category\": \"\",\n      \"notification_delivery_method\": \"\",\n      \"notification_target\": \"\"\n    }\n  ],\n  \"public_nick_name\": \"\",\n  \"public_uuid\": \"\",\n  \"region\": \"\",\n  \"relations\": [\n    {\n      \"counter_label_user\": {},\n      \"counter_user_id\": \"\",\n      \"counter_user_status\": \"\",\n      \"label_user\": {},\n      \"relationship\": \"\",\n      \"status\": \"\",\n      \"user_id\": \"\",\n      \"user_status\": \"\"\n    }\n  ],\n  \"sector_of_industry\": \"\",\n  \"session_timeout\": 0,\n  \"status\": \"\",\n  \"sub_status\": \"\",\n  \"tax_resident\": [\n    {\n      \"country\": \"\",\n      \"status\": \"\",\n      \"tax_number\": \"\"\n    }\n  ],\n  \"type_of_business_entity\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"updated\": \"\",\n  \"version_terms_of_service\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user-company/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"avatar\": {\n    \"anchor_uuid\": \"\",\n    \"image\": [\n      {\n        \"attachment_public_uuid\": \"\",\n        \"content_type\": \"\",\n        \"height\": 0,\n        \"width\": 0\n      }\n    ],\n    \"style\": \"\",\n    \"uuid\": \"\"\n  },\n  \"avatar_uuid\": \"\",\n  \"billing_contract\": [\n    {\n      \"contract_date_end\": \"\",\n      \"contract_date_start\": \"\",\n      \"contract_version\": 0,\n      \"created\": \"\",\n      \"id\": 0,\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"subscription_type\": \"\",\n      \"subscription_type_downgrade\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"chamber_of_commerce_number\": \"\",\n  \"counter_bank_iban\": \"\",\n  \"country\": \"\",\n  \"created\": \"\",\n  \"customer\": {\n    \"billing_account_id\": \"\",\n    \"created\": \"\",\n    \"id\": 0,\n    \"invoice_notification_preference\": \"\",\n    \"updated\": \"\"\n  },\n  \"customer_limit\": {\n    \"limit_amount_monthly\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"limit_card_debit_maestro\": 0,\n    \"limit_card_debit_mastercard\": 0,\n    \"limit_card_debit_wildcard\": 0,\n    \"limit_card_replacement\": 0,\n    \"limit_card_wildcard\": 0,\n    \"limit_monetary_account\": 0,\n    \"limit_monetary_account_remaining\": 0,\n    \"spent_amount_monthly\": {}\n  },\n  \"daily_limit_without_confirmation_login\": {},\n  \"deny_reason\": \"\",\n  \"directors\": [\n    {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    }\n  ],\n  \"display_name\": \"\",\n  \"id\": 0,\n  \"language\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"notification_filters\": [\n    {\n      \"category\": \"\",\n      \"notification_delivery_method\": \"\",\n      \"notification_target\": \"\"\n    }\n  ],\n  \"public_nick_name\": \"\",\n  \"public_uuid\": \"\",\n  \"region\": \"\",\n  \"relations\": [\n    {\n      \"counter_label_user\": {},\n      \"counter_user_id\": \"\",\n      \"counter_user_status\": \"\",\n      \"label_user\": {},\n      \"relationship\": \"\",\n      \"status\": \"\",\n      \"user_id\": \"\",\n      \"user_status\": \"\"\n    }\n  ],\n  \"sector_of_industry\": \"\",\n  \"session_timeout\": 0,\n  \"status\": \"\",\n  \"sub_status\": \"\",\n  \"tax_resident\": [\n    {\n      \"country\": \"\",\n      \"status\": \"\",\n      \"tax_number\": \"\"\n    }\n  ],\n  \"type_of_business_entity\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"updated\": \"\",\n  \"version_terms_of_service\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user-company/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"avatar\": {\n    \"anchor_uuid\": \"\",\n    \"image\": [\n      {\n        \"attachment_public_uuid\": \"\",\n        \"content_type\": \"\",\n        \"height\": 0,\n        \"width\": 0\n      }\n    ],\n    \"style\": \"\",\n    \"uuid\": \"\"\n  },\n  \"avatar_uuid\": \"\",\n  \"billing_contract\": [\n    {\n      \"contract_date_end\": \"\",\n      \"contract_date_start\": \"\",\n      \"contract_version\": 0,\n      \"created\": \"\",\n      \"id\": 0,\n      \"status\": \"\",\n      \"sub_status\": \"\",\n      \"subscription_type\": \"\",\n      \"subscription_type_downgrade\": \"\",\n      \"updated\": \"\"\n    }\n  ],\n  \"chamber_of_commerce_number\": \"\",\n  \"counter_bank_iban\": \"\",\n  \"country\": \"\",\n  \"created\": \"\",\n  \"customer\": {\n    \"billing_account_id\": \"\",\n    \"created\": \"\",\n    \"id\": 0,\n    \"invoice_notification_preference\": \"\",\n    \"updated\": \"\"\n  },\n  \"customer_limit\": {\n    \"limit_amount_monthly\": {\n      \"currency\": \"\",\n      \"value\": \"\"\n    },\n    \"limit_card_debit_maestro\": 0,\n    \"limit_card_debit_mastercard\": 0,\n    \"limit_card_debit_wildcard\": 0,\n    \"limit_card_replacement\": 0,\n    \"limit_card_wildcard\": 0,\n    \"limit_monetary_account\": 0,\n    \"limit_monetary_account_remaining\": 0,\n    \"spent_amount_monthly\": {}\n  },\n  \"daily_limit_without_confirmation_login\": {},\n  \"deny_reason\": \"\",\n  \"directors\": [\n    {\n      \"avatar\": {},\n      \"country\": \"\",\n      \"display_name\": \"\",\n      \"public_nick_name\": \"\",\n      \"uuid\": \"\"\n    }\n  ],\n  \"display_name\": \"\",\n  \"id\": 0,\n  \"language\": \"\",\n  \"legal_form\": \"\",\n  \"name\": \"\",\n  \"notification_filters\": [\n    {\n      \"category\": \"\",\n      \"notification_delivery_method\": \"\",\n      \"notification_target\": \"\"\n    }\n  ],\n  \"public_nick_name\": \"\",\n  \"public_uuid\": \"\",\n  \"region\": \"\",\n  \"relations\": [\n    {\n      \"counter_label_user\": {},\n      \"counter_user_id\": \"\",\n      \"counter_user_status\": \"\",\n      \"label_user\": {},\n      \"relationship\": \"\",\n      \"status\": \"\",\n      \"user_id\": \"\",\n      \"user_status\": \"\"\n    }\n  ],\n  \"sector_of_industry\": \"\",\n  \"session_timeout\": 0,\n  \"status\": \"\",\n  \"sub_status\": \"\",\n  \"tax_resident\": [\n    {\n      \"country\": \"\",\n      \"status\": \"\",\n      \"tax_number\": \"\"\n    }\n  ],\n  \"type_of_business_entity\": \"\",\n  \"ubo\": [\n    {\n      \"date_of_birth\": \"\",\n      \"name\": \"\",\n      \"nationality\": \"\"\n    }\n  ],\n  \"updated\": \"\",\n  \"version_terms_of_service\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user-company/:itemId";

    let payload = json!({
        "address_main": json!({
            "city": "",
            "country": "",
            "extra": "",
            "house_number": "",
            "is_user_address_updated": false,
            "mailbox_name": "",
            "po_box": "",
            "postal_code": "",
            "province": "",
            "street": ""
        }),
        "address_postal": json!({}),
        "alias": (
            json!({
                "name": "",
                "service": "",
                "type": "",
                "value": ""
            })
        ),
        "avatar": json!({
            "anchor_uuid": "",
            "image": (
                json!({
                    "attachment_public_uuid": "",
                    "content_type": "",
                    "height": 0,
                    "width": 0
                })
            ),
            "style": "",
            "uuid": ""
        }),
        "avatar_uuid": "",
        "billing_contract": (
            json!({
                "contract_date_end": "",
                "contract_date_start": "",
                "contract_version": 0,
                "created": "",
                "id": 0,
                "status": "",
                "sub_status": "",
                "subscription_type": "",
                "subscription_type_downgrade": "",
                "updated": ""
            })
        ),
        "chamber_of_commerce_number": "",
        "counter_bank_iban": "",
        "country": "",
        "created": "",
        "customer": json!({
            "billing_account_id": "",
            "created": "",
            "id": 0,
            "invoice_notification_preference": "",
            "updated": ""
        }),
        "customer_limit": json!({
            "limit_amount_monthly": json!({
                "currency": "",
                "value": ""
            }),
            "limit_card_debit_maestro": 0,
            "limit_card_debit_mastercard": 0,
            "limit_card_debit_wildcard": 0,
            "limit_card_replacement": 0,
            "limit_card_wildcard": 0,
            "limit_monetary_account": 0,
            "limit_monetary_account_remaining": 0,
            "spent_amount_monthly": json!({})
        }),
        "daily_limit_without_confirmation_login": json!({}),
        "deny_reason": "",
        "directors": (
            json!({
                "avatar": json!({}),
                "country": "",
                "display_name": "",
                "public_nick_name": "",
                "uuid": ""
            })
        ),
        "display_name": "",
        "id": 0,
        "language": "",
        "legal_form": "",
        "name": "",
        "notification_filters": (
            json!({
                "category": "",
                "notification_delivery_method": "",
                "notification_target": ""
            })
        ),
        "public_nick_name": "",
        "public_uuid": "",
        "region": "",
        "relations": (
            json!({
                "counter_label_user": json!({}),
                "counter_user_id": "",
                "counter_user_status": "",
                "label_user": json!({}),
                "relationship": "",
                "status": "",
                "user_id": "",
                "user_status": ""
            })
        ),
        "sector_of_industry": "",
        "session_timeout": 0,
        "status": "",
        "sub_status": "",
        "tax_resident": (
            json!({
                "country": "",
                "status": "",
                "tax_number": ""
            })
        ),
        "type_of_business_entity": "",
        "ubo": (
            json!({
                "date_of_birth": "",
                "name": "",
                "nationality": ""
            })
        ),
        "updated": "",
        "version_terms_of_service": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user-company/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "address_main": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_postal": {},
  "alias": [
    {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    }
  ],
  "avatar": {
    "anchor_uuid": "",
    "image": [
      {
        "attachment_public_uuid": "",
        "content_type": "",
        "height": 0,
        "width": 0
      }
    ],
    "style": "",
    "uuid": ""
  },
  "avatar_uuid": "",
  "billing_contract": [
    {
      "contract_date_end": "",
      "contract_date_start": "",
      "contract_version": 0,
      "created": "",
      "id": 0,
      "status": "",
      "sub_status": "",
      "subscription_type": "",
      "subscription_type_downgrade": "",
      "updated": ""
    }
  ],
  "chamber_of_commerce_number": "",
  "counter_bank_iban": "",
  "country": "",
  "created": "",
  "customer": {
    "billing_account_id": "",
    "created": "",
    "id": 0,
    "invoice_notification_preference": "",
    "updated": ""
  },
  "customer_limit": {
    "limit_amount_monthly": {
      "currency": "",
      "value": ""
    },
    "limit_card_debit_maestro": 0,
    "limit_card_debit_mastercard": 0,
    "limit_card_debit_wildcard": 0,
    "limit_card_replacement": 0,
    "limit_card_wildcard": 0,
    "limit_monetary_account": 0,
    "limit_monetary_account_remaining": 0,
    "spent_amount_monthly": {}
  },
  "daily_limit_without_confirmation_login": {},
  "deny_reason": "",
  "directors": [
    {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    }
  ],
  "display_name": "",
  "id": 0,
  "language": "",
  "legal_form": "",
  "name": "",
  "notification_filters": [
    {
      "category": "",
      "notification_delivery_method": "",
      "notification_target": ""
    }
  ],
  "public_nick_name": "",
  "public_uuid": "",
  "region": "",
  "relations": [
    {
      "counter_label_user": {},
      "counter_user_id": "",
      "counter_user_status": "",
      "label_user": {},
      "relationship": "",
      "status": "",
      "user_id": "",
      "user_status": ""
    }
  ],
  "sector_of_industry": "",
  "session_timeout": 0,
  "status": "",
  "sub_status": "",
  "tax_resident": [
    {
      "country": "",
      "status": "",
      "tax_number": ""
    }
  ],
  "type_of_business_entity": "",
  "ubo": [
    {
      "date_of_birth": "",
      "name": "",
      "nationality": ""
    }
  ],
  "updated": "",
  "version_terms_of_service": ""
}'
echo '{
  "address_main": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_postal": {},
  "alias": [
    {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    }
  ],
  "avatar": {
    "anchor_uuid": "",
    "image": [
      {
        "attachment_public_uuid": "",
        "content_type": "",
        "height": 0,
        "width": 0
      }
    ],
    "style": "",
    "uuid": ""
  },
  "avatar_uuid": "",
  "billing_contract": [
    {
      "contract_date_end": "",
      "contract_date_start": "",
      "contract_version": 0,
      "created": "",
      "id": 0,
      "status": "",
      "sub_status": "",
      "subscription_type": "",
      "subscription_type_downgrade": "",
      "updated": ""
    }
  ],
  "chamber_of_commerce_number": "",
  "counter_bank_iban": "",
  "country": "",
  "created": "",
  "customer": {
    "billing_account_id": "",
    "created": "",
    "id": 0,
    "invoice_notification_preference": "",
    "updated": ""
  },
  "customer_limit": {
    "limit_amount_monthly": {
      "currency": "",
      "value": ""
    },
    "limit_card_debit_maestro": 0,
    "limit_card_debit_mastercard": 0,
    "limit_card_debit_wildcard": 0,
    "limit_card_replacement": 0,
    "limit_card_wildcard": 0,
    "limit_monetary_account": 0,
    "limit_monetary_account_remaining": 0,
    "spent_amount_monthly": {}
  },
  "daily_limit_without_confirmation_login": {},
  "deny_reason": "",
  "directors": [
    {
      "avatar": {},
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    }
  ],
  "display_name": "",
  "id": 0,
  "language": "",
  "legal_form": "",
  "name": "",
  "notification_filters": [
    {
      "category": "",
      "notification_delivery_method": "",
      "notification_target": ""
    }
  ],
  "public_nick_name": "",
  "public_uuid": "",
  "region": "",
  "relations": [
    {
      "counter_label_user": {},
      "counter_user_id": "",
      "counter_user_status": "",
      "label_user": {},
      "relationship": "",
      "status": "",
      "user_id": "",
      "user_status": ""
    }
  ],
  "sector_of_industry": "",
  "session_timeout": 0,
  "status": "",
  "sub_status": "",
  "tax_resident": [
    {
      "country": "",
      "status": "",
      "tax_number": ""
    }
  ],
  "type_of_business_entity": "",
  "ubo": [
    {
      "date_of_birth": "",
      "name": "",
      "nationality": ""
    }
  ],
  "updated": "",
  "version_terms_of_service": ""
}' |  \
  http PUT {{baseUrl}}/user-company/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "address_main": {\n    "city": "",\n    "country": "",\n    "extra": "",\n    "house_number": "",\n    "is_user_address_updated": false,\n    "mailbox_name": "",\n    "po_box": "",\n    "postal_code": "",\n    "province": "",\n    "street": ""\n  },\n  "address_postal": {},\n  "alias": [\n    {\n      "name": "",\n      "service": "",\n      "type": "",\n      "value": ""\n    }\n  ],\n  "avatar": {\n    "anchor_uuid": "",\n    "image": [\n      {\n        "attachment_public_uuid": "",\n        "content_type": "",\n        "height": 0,\n        "width": 0\n      }\n    ],\n    "style": "",\n    "uuid": ""\n  },\n  "avatar_uuid": "",\n  "billing_contract": [\n    {\n      "contract_date_end": "",\n      "contract_date_start": "",\n      "contract_version": 0,\n      "created": "",\n      "id": 0,\n      "status": "",\n      "sub_status": "",\n      "subscription_type": "",\n      "subscription_type_downgrade": "",\n      "updated": ""\n    }\n  ],\n  "chamber_of_commerce_number": "",\n  "counter_bank_iban": "",\n  "country": "",\n  "created": "",\n  "customer": {\n    "billing_account_id": "",\n    "created": "",\n    "id": 0,\n    "invoice_notification_preference": "",\n    "updated": ""\n  },\n  "customer_limit": {\n    "limit_amount_monthly": {\n      "currency": "",\n      "value": ""\n    },\n    "limit_card_debit_maestro": 0,\n    "limit_card_debit_mastercard": 0,\n    "limit_card_debit_wildcard": 0,\n    "limit_card_replacement": 0,\n    "limit_card_wildcard": 0,\n    "limit_monetary_account": 0,\n    "limit_monetary_account_remaining": 0,\n    "spent_amount_monthly": {}\n  },\n  "daily_limit_without_confirmation_login": {},\n  "deny_reason": "",\n  "directors": [\n    {\n      "avatar": {},\n      "country": "",\n      "display_name": "",\n      "public_nick_name": "",\n      "uuid": ""\n    }\n  ],\n  "display_name": "",\n  "id": 0,\n  "language": "",\n  "legal_form": "",\n  "name": "",\n  "notification_filters": [\n    {\n      "category": "",\n      "notification_delivery_method": "",\n      "notification_target": ""\n    }\n  ],\n  "public_nick_name": "",\n  "public_uuid": "",\n  "region": "",\n  "relations": [\n    {\n      "counter_label_user": {},\n      "counter_user_id": "",\n      "counter_user_status": "",\n      "label_user": {},\n      "relationship": "",\n      "status": "",\n      "user_id": "",\n      "user_status": ""\n    }\n  ],\n  "sector_of_industry": "",\n  "session_timeout": 0,\n  "status": "",\n  "sub_status": "",\n  "tax_resident": [\n    {\n      "country": "",\n      "status": "",\n      "tax_number": ""\n    }\n  ],\n  "type_of_business_entity": "",\n  "ubo": [\n    {\n      "date_of_birth": "",\n      "name": "",\n      "nationality": ""\n    }\n  ],\n  "updated": "",\n  "version_terms_of_service": ""\n}' \
  --output-document \
  - {{baseUrl}}/user-company/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "address_main": [
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  ],
  "address_postal": [],
  "alias": [
    [
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    ]
  ],
  "avatar": [
    "anchor_uuid": "",
    "image": [
      [
        "attachment_public_uuid": "",
        "content_type": "",
        "height": 0,
        "width": 0
      ]
    ],
    "style": "",
    "uuid": ""
  ],
  "avatar_uuid": "",
  "billing_contract": [
    [
      "contract_date_end": "",
      "contract_date_start": "",
      "contract_version": 0,
      "created": "",
      "id": 0,
      "status": "",
      "sub_status": "",
      "subscription_type": "",
      "subscription_type_downgrade": "",
      "updated": ""
    ]
  ],
  "chamber_of_commerce_number": "",
  "counter_bank_iban": "",
  "country": "",
  "created": "",
  "customer": [
    "billing_account_id": "",
    "created": "",
    "id": 0,
    "invoice_notification_preference": "",
    "updated": ""
  ],
  "customer_limit": [
    "limit_amount_monthly": [
      "currency": "",
      "value": ""
    ],
    "limit_card_debit_maestro": 0,
    "limit_card_debit_mastercard": 0,
    "limit_card_debit_wildcard": 0,
    "limit_card_replacement": 0,
    "limit_card_wildcard": 0,
    "limit_monetary_account": 0,
    "limit_monetary_account_remaining": 0,
    "spent_amount_monthly": []
  ],
  "daily_limit_without_confirmation_login": [],
  "deny_reason": "",
  "directors": [
    [
      "avatar": [],
      "country": "",
      "display_name": "",
      "public_nick_name": "",
      "uuid": ""
    ]
  ],
  "display_name": "",
  "id": 0,
  "language": "",
  "legal_form": "",
  "name": "",
  "notification_filters": [
    [
      "category": "",
      "notification_delivery_method": "",
      "notification_target": ""
    ]
  ],
  "public_nick_name": "",
  "public_uuid": "",
  "region": "",
  "relations": [
    [
      "counter_label_user": [],
      "counter_user_id": "",
      "counter_user_status": "",
      "label_user": [],
      "relationship": "",
      "status": "",
      "user_id": "",
      "user_status": ""
    ]
  ],
  "sector_of_industry": "",
  "session_timeout": 0,
  "status": "",
  "sub_status": "",
  "tax_resident": [
    [
      "country": "",
      "status": "",
      "tax_number": ""
    ]
  ],
  "type_of_business_entity": "",
  "ubo": [
    [
      "date_of_birth": "",
      "name": "",
      "nationality": ""
    ]
  ],
  "updated": "",
  "version_terms_of_service": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user-company/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_UserPaymentServiceProvider
{{baseUrl}}/user-payment-service-provider/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user-payment-service-provider/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user-payment-service-provider/:itemId" {:headers {:user-agent ""
                                                                                           :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user-payment-service-provider/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user-payment-service-provider/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user-payment-service-provider/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user-payment-service-provider/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user-payment-service-provider/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user-payment-service-provider/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user-payment-service-provider/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user-payment-service-provider/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user-payment-service-provider/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user-payment-service-provider/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user-payment-service-provider/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user-payment-service-provider/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user-payment-service-provider/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user-payment-service-provider/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user-payment-service-provider/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user-payment-service-provider/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user-payment-service-provider/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user-payment-service-provider/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user-payment-service-provider/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user-payment-service-provider/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user-payment-service-provider/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user-payment-service-provider/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user-payment-service-provider/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user-payment-service-provider/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user-payment-service-provider/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user-payment-service-provider/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user-payment-service-provider/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user-payment-service-provider/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user-payment-service-provider/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user-payment-service-provider/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user-payment-service-provider/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user-payment-service-provider/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user-payment-service-provider/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user-payment-service-provider/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user-payment-service-provider/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user-payment-service-provider/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user-payment-service-provider/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_UserPerson
{{baseUrl}}/user-person/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user-person/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user-person/:itemId" {:headers {:user-agent ""
                                                                         :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user-person/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user-person/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user-person/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user-person/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user-person/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user-person/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user-person/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user-person/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user-person/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user-person/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user-person/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user-person/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user-person/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user-person/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user-person/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user-person/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user-person/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user-person/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user-person/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user-person/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user-person/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user-person/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user-person/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user-person/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user-person/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user-person/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user-person/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user-person/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user-person/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user-person/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user-person/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user-person/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user-person/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user-person/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user-person/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user-person/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user-person/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_UserPerson
{{baseUrl}}/user-person/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

itemId
BODY json

{
  "address_main": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_postal": {},
  "alias": [
    {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    }
  ],
  "avatar": {
    "anchor_uuid": "",
    "image": [
      {
        "attachment_public_uuid": "",
        "content_type": "",
        "height": 0,
        "width": 0
      }
    ],
    "style": "",
    "uuid": ""
  },
  "avatar_uuid": "",
  "country_of_birth": "",
  "created": "",
  "daily_limit_without_confirmation_login": {
    "currency": "",
    "value": ""
  },
  "date_of_birth": "",
  "display_name": "",
  "document_back_attachment_id": 0,
  "document_country_of_issuance": "",
  "document_front_attachment_id": 0,
  "document_number": "",
  "document_type": "",
  "first_name": "",
  "gender": "",
  "id": 0,
  "language": "",
  "last_name": "",
  "legal_guardian_alias": {},
  "legal_name": "",
  "middle_name": "",
  "nationality": "",
  "notification_filters": [
    {
      "category": "",
      "notification_delivery_method": "",
      "notification_target": ""
    }
  ],
  "place_of_birth": "",
  "public_nick_name": "",
  "public_uuid": "",
  "region": "",
  "relations": [
    {
      "counter_label_user": {
        "avatar": {},
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "counter_user_id": "",
      "counter_user_status": "",
      "label_user": {},
      "relationship": "",
      "status": "",
      "user_id": "",
      "user_status": ""
    }
  ],
  "session_timeout": 0,
  "signup_track_type": "",
  "status": "",
  "sub_status": "",
  "subscription_type": "",
  "tax_resident": [
    {
      "country": "",
      "status": "",
      "tax_number": ""
    }
  ],
  "updated": "",
  "version_terms_of_service": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user-person/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"avatar\": {\n    \"anchor_uuid\": \"\",\n    \"image\": [\n      {\n        \"attachment_public_uuid\": \"\",\n        \"content_type\": \"\",\n        \"height\": 0,\n        \"width\": 0\n      }\n    ],\n    \"style\": \"\",\n    \"uuid\": \"\"\n  },\n  \"avatar_uuid\": \"\",\n  \"country_of_birth\": \"\",\n  \"created\": \"\",\n  \"daily_limit_without_confirmation_login\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"date_of_birth\": \"\",\n  \"display_name\": \"\",\n  \"document_back_attachment_id\": 0,\n  \"document_country_of_issuance\": \"\",\n  \"document_front_attachment_id\": 0,\n  \"document_number\": \"\",\n  \"document_type\": \"\",\n  \"first_name\": \"\",\n  \"gender\": \"\",\n  \"id\": 0,\n  \"language\": \"\",\n  \"last_name\": \"\",\n  \"legal_guardian_alias\": {},\n  \"legal_name\": \"\",\n  \"middle_name\": \"\",\n  \"nationality\": \"\",\n  \"notification_filters\": [\n    {\n      \"category\": \"\",\n      \"notification_delivery_method\": \"\",\n      \"notification_target\": \"\"\n    }\n  ],\n  \"place_of_birth\": \"\",\n  \"public_nick_name\": \"\",\n  \"public_uuid\": \"\",\n  \"region\": \"\",\n  \"relations\": [\n    {\n      \"counter_label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"counter_user_id\": \"\",\n      \"counter_user_status\": \"\",\n      \"label_user\": {},\n      \"relationship\": \"\",\n      \"status\": \"\",\n      \"user_id\": \"\",\n      \"user_status\": \"\"\n    }\n  ],\n  \"session_timeout\": 0,\n  \"signup_track_type\": \"\",\n  \"status\": \"\",\n  \"sub_status\": \"\",\n  \"subscription_type\": \"\",\n  \"tax_resident\": [\n    {\n      \"country\": \"\",\n      \"status\": \"\",\n      \"tax_number\": \"\"\n    }\n  ],\n  \"updated\": \"\",\n  \"version_terms_of_service\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user-person/:itemId" {:headers {:user-agent ""
                                                                         :x-bunq-client-authentication ""}
                                                               :content-type :json
                                                               :form-params {:address_main {:city ""
                                                                                            :country ""
                                                                                            :extra ""
                                                                                            :house_number ""
                                                                                            :is_user_address_updated false
                                                                                            :mailbox_name ""
                                                                                            :po_box ""
                                                                                            :postal_code ""
                                                                                            :province ""
                                                                                            :street ""}
                                                                             :address_postal {}
                                                                             :alias [{:name ""
                                                                                      :service ""
                                                                                      :type ""
                                                                                      :value ""}]
                                                                             :avatar {:anchor_uuid ""
                                                                                      :image [{:attachment_public_uuid ""
                                                                                               :content_type ""
                                                                                               :height 0
                                                                                               :width 0}]
                                                                                      :style ""
                                                                                      :uuid ""}
                                                                             :avatar_uuid ""
                                                                             :country_of_birth ""
                                                                             :created ""
                                                                             :daily_limit_without_confirmation_login {:currency ""
                                                                                                                      :value ""}
                                                                             :date_of_birth ""
                                                                             :display_name ""
                                                                             :document_back_attachment_id 0
                                                                             :document_country_of_issuance ""
                                                                             :document_front_attachment_id 0
                                                                             :document_number ""
                                                                             :document_type ""
                                                                             :first_name ""
                                                                             :gender ""
                                                                             :id 0
                                                                             :language ""
                                                                             :last_name ""
                                                                             :legal_guardian_alias {}
                                                                             :legal_name ""
                                                                             :middle_name ""
                                                                             :nationality ""
                                                                             :notification_filters [{:category ""
                                                                                                     :notification_delivery_method ""
                                                                                                     :notification_target ""}]
                                                                             :place_of_birth ""
                                                                             :public_nick_name ""
                                                                             :public_uuid ""
                                                                             :region ""
                                                                             :relations [{:counter_label_user {:avatar {}
                                                                                                               :country ""
                                                                                                               :display_name ""
                                                                                                               :public_nick_name ""
                                                                                                               :uuid ""}
                                                                                          :counter_user_id ""
                                                                                          :counter_user_status ""
                                                                                          :label_user {}
                                                                                          :relationship ""
                                                                                          :status ""
                                                                                          :user_id ""
                                                                                          :user_status ""}]
                                                                             :session_timeout 0
                                                                             :signup_track_type ""
                                                                             :status ""
                                                                             :sub_status ""
                                                                             :subscription_type ""
                                                                             :tax_resident [{:country ""
                                                                                             :status ""
                                                                                             :tax_number ""}]
                                                                             :updated ""
                                                                             :version_terms_of_service ""}})
require "http/client"

url = "{{baseUrl}}/user-person/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"avatar\": {\n    \"anchor_uuid\": \"\",\n    \"image\": [\n      {\n        \"attachment_public_uuid\": \"\",\n        \"content_type\": \"\",\n        \"height\": 0,\n        \"width\": 0\n      }\n    ],\n    \"style\": \"\",\n    \"uuid\": \"\"\n  },\n  \"avatar_uuid\": \"\",\n  \"country_of_birth\": \"\",\n  \"created\": \"\",\n  \"daily_limit_without_confirmation_login\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"date_of_birth\": \"\",\n  \"display_name\": \"\",\n  \"document_back_attachment_id\": 0,\n  \"document_country_of_issuance\": \"\",\n  \"document_front_attachment_id\": 0,\n  \"document_number\": \"\",\n  \"document_type\": \"\",\n  \"first_name\": \"\",\n  \"gender\": \"\",\n  \"id\": 0,\n  \"language\": \"\",\n  \"last_name\": \"\",\n  \"legal_guardian_alias\": {},\n  \"legal_name\": \"\",\n  \"middle_name\": \"\",\n  \"nationality\": \"\",\n  \"notification_filters\": [\n    {\n      \"category\": \"\",\n      \"notification_delivery_method\": \"\",\n      \"notification_target\": \"\"\n    }\n  ],\n  \"place_of_birth\": \"\",\n  \"public_nick_name\": \"\",\n  \"public_uuid\": \"\",\n  \"region\": \"\",\n  \"relations\": [\n    {\n      \"counter_label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"counter_user_id\": \"\",\n      \"counter_user_status\": \"\",\n      \"label_user\": {},\n      \"relationship\": \"\",\n      \"status\": \"\",\n      \"user_id\": \"\",\n      \"user_status\": \"\"\n    }\n  ],\n  \"session_timeout\": 0,\n  \"signup_track_type\": \"\",\n  \"status\": \"\",\n  \"sub_status\": \"\",\n  \"subscription_type\": \"\",\n  \"tax_resident\": [\n    {\n      \"country\": \"\",\n      \"status\": \"\",\n      \"tax_number\": \"\"\n    }\n  ],\n  \"updated\": \"\",\n  \"version_terms_of_service\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user-person/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"avatar\": {\n    \"anchor_uuid\": \"\",\n    \"image\": [\n      {\n        \"attachment_public_uuid\": \"\",\n        \"content_type\": \"\",\n        \"height\": 0,\n        \"width\": 0\n      }\n    ],\n    \"style\": \"\",\n    \"uuid\": \"\"\n  },\n  \"avatar_uuid\": \"\",\n  \"country_of_birth\": \"\",\n  \"created\": \"\",\n  \"daily_limit_without_confirmation_login\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"date_of_birth\": \"\",\n  \"display_name\": \"\",\n  \"document_back_attachment_id\": 0,\n  \"document_country_of_issuance\": \"\",\n  \"document_front_attachment_id\": 0,\n  \"document_number\": \"\",\n  \"document_type\": \"\",\n  \"first_name\": \"\",\n  \"gender\": \"\",\n  \"id\": 0,\n  \"language\": \"\",\n  \"last_name\": \"\",\n  \"legal_guardian_alias\": {},\n  \"legal_name\": \"\",\n  \"middle_name\": \"\",\n  \"nationality\": \"\",\n  \"notification_filters\": [\n    {\n      \"category\": \"\",\n      \"notification_delivery_method\": \"\",\n      \"notification_target\": \"\"\n    }\n  ],\n  \"place_of_birth\": \"\",\n  \"public_nick_name\": \"\",\n  \"public_uuid\": \"\",\n  \"region\": \"\",\n  \"relations\": [\n    {\n      \"counter_label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"counter_user_id\": \"\",\n      \"counter_user_status\": \"\",\n      \"label_user\": {},\n      \"relationship\": \"\",\n      \"status\": \"\",\n      \"user_id\": \"\",\n      \"user_status\": \"\"\n    }\n  ],\n  \"session_timeout\": 0,\n  \"signup_track_type\": \"\",\n  \"status\": \"\",\n  \"sub_status\": \"\",\n  \"subscription_type\": \"\",\n  \"tax_resident\": [\n    {\n      \"country\": \"\",\n      \"status\": \"\",\n      \"tax_number\": \"\"\n    }\n  ],\n  \"updated\": \"\",\n  \"version_terms_of_service\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user-person/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"avatar\": {\n    \"anchor_uuid\": \"\",\n    \"image\": [\n      {\n        \"attachment_public_uuid\": \"\",\n        \"content_type\": \"\",\n        \"height\": 0,\n        \"width\": 0\n      }\n    ],\n    \"style\": \"\",\n    \"uuid\": \"\"\n  },\n  \"avatar_uuid\": \"\",\n  \"country_of_birth\": \"\",\n  \"created\": \"\",\n  \"daily_limit_without_confirmation_login\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"date_of_birth\": \"\",\n  \"display_name\": \"\",\n  \"document_back_attachment_id\": 0,\n  \"document_country_of_issuance\": \"\",\n  \"document_front_attachment_id\": 0,\n  \"document_number\": \"\",\n  \"document_type\": \"\",\n  \"first_name\": \"\",\n  \"gender\": \"\",\n  \"id\": 0,\n  \"language\": \"\",\n  \"last_name\": \"\",\n  \"legal_guardian_alias\": {},\n  \"legal_name\": \"\",\n  \"middle_name\": \"\",\n  \"nationality\": \"\",\n  \"notification_filters\": [\n    {\n      \"category\": \"\",\n      \"notification_delivery_method\": \"\",\n      \"notification_target\": \"\"\n    }\n  ],\n  \"place_of_birth\": \"\",\n  \"public_nick_name\": \"\",\n  \"public_uuid\": \"\",\n  \"region\": \"\",\n  \"relations\": [\n    {\n      \"counter_label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"counter_user_id\": \"\",\n      \"counter_user_status\": \"\",\n      \"label_user\": {},\n      \"relationship\": \"\",\n      \"status\": \"\",\n      \"user_id\": \"\",\n      \"user_status\": \"\"\n    }\n  ],\n  \"session_timeout\": 0,\n  \"signup_track_type\": \"\",\n  \"status\": \"\",\n  \"sub_status\": \"\",\n  \"subscription_type\": \"\",\n  \"tax_resident\": [\n    {\n      \"country\": \"\",\n      \"status\": \"\",\n      \"tax_number\": \"\"\n    }\n  ],\n  \"updated\": \"\",\n  \"version_terms_of_service\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user-person/:itemId"

	payload := strings.NewReader("{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"avatar\": {\n    \"anchor_uuid\": \"\",\n    \"image\": [\n      {\n        \"attachment_public_uuid\": \"\",\n        \"content_type\": \"\",\n        \"height\": 0,\n        \"width\": 0\n      }\n    ],\n    \"style\": \"\",\n    \"uuid\": \"\"\n  },\n  \"avatar_uuid\": \"\",\n  \"country_of_birth\": \"\",\n  \"created\": \"\",\n  \"daily_limit_without_confirmation_login\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"date_of_birth\": \"\",\n  \"display_name\": \"\",\n  \"document_back_attachment_id\": 0,\n  \"document_country_of_issuance\": \"\",\n  \"document_front_attachment_id\": 0,\n  \"document_number\": \"\",\n  \"document_type\": \"\",\n  \"first_name\": \"\",\n  \"gender\": \"\",\n  \"id\": 0,\n  \"language\": \"\",\n  \"last_name\": \"\",\n  \"legal_guardian_alias\": {},\n  \"legal_name\": \"\",\n  \"middle_name\": \"\",\n  \"nationality\": \"\",\n  \"notification_filters\": [\n    {\n      \"category\": \"\",\n      \"notification_delivery_method\": \"\",\n      \"notification_target\": \"\"\n    }\n  ],\n  \"place_of_birth\": \"\",\n  \"public_nick_name\": \"\",\n  \"public_uuid\": \"\",\n  \"region\": \"\",\n  \"relations\": [\n    {\n      \"counter_label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"counter_user_id\": \"\",\n      \"counter_user_status\": \"\",\n      \"label_user\": {},\n      \"relationship\": \"\",\n      \"status\": \"\",\n      \"user_id\": \"\",\n      \"user_status\": \"\"\n    }\n  ],\n  \"session_timeout\": 0,\n  \"signup_track_type\": \"\",\n  \"status\": \"\",\n  \"sub_status\": \"\",\n  \"subscription_type\": \"\",\n  \"tax_resident\": [\n    {\n      \"country\": \"\",\n      \"status\": \"\",\n      \"tax_number\": \"\"\n    }\n  ],\n  \"updated\": \"\",\n  \"version_terms_of_service\": \"\"\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user-person/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 1989

{
  "address_main": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_postal": {},
  "alias": [
    {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    }
  ],
  "avatar": {
    "anchor_uuid": "",
    "image": [
      {
        "attachment_public_uuid": "",
        "content_type": "",
        "height": 0,
        "width": 0
      }
    ],
    "style": "",
    "uuid": ""
  },
  "avatar_uuid": "",
  "country_of_birth": "",
  "created": "",
  "daily_limit_without_confirmation_login": {
    "currency": "",
    "value": ""
  },
  "date_of_birth": "",
  "display_name": "",
  "document_back_attachment_id": 0,
  "document_country_of_issuance": "",
  "document_front_attachment_id": 0,
  "document_number": "",
  "document_type": "",
  "first_name": "",
  "gender": "",
  "id": 0,
  "language": "",
  "last_name": "",
  "legal_guardian_alias": {},
  "legal_name": "",
  "middle_name": "",
  "nationality": "",
  "notification_filters": [
    {
      "category": "",
      "notification_delivery_method": "",
      "notification_target": ""
    }
  ],
  "place_of_birth": "",
  "public_nick_name": "",
  "public_uuid": "",
  "region": "",
  "relations": [
    {
      "counter_label_user": {
        "avatar": {},
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "counter_user_id": "",
      "counter_user_status": "",
      "label_user": {},
      "relationship": "",
      "status": "",
      "user_id": "",
      "user_status": ""
    }
  ],
  "session_timeout": 0,
  "signup_track_type": "",
  "status": "",
  "sub_status": "",
  "subscription_type": "",
  "tax_resident": [
    {
      "country": "",
      "status": "",
      "tax_number": ""
    }
  ],
  "updated": "",
  "version_terms_of_service": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user-person/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"avatar\": {\n    \"anchor_uuid\": \"\",\n    \"image\": [\n      {\n        \"attachment_public_uuid\": \"\",\n        \"content_type\": \"\",\n        \"height\": 0,\n        \"width\": 0\n      }\n    ],\n    \"style\": \"\",\n    \"uuid\": \"\"\n  },\n  \"avatar_uuid\": \"\",\n  \"country_of_birth\": \"\",\n  \"created\": \"\",\n  \"daily_limit_without_confirmation_login\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"date_of_birth\": \"\",\n  \"display_name\": \"\",\n  \"document_back_attachment_id\": 0,\n  \"document_country_of_issuance\": \"\",\n  \"document_front_attachment_id\": 0,\n  \"document_number\": \"\",\n  \"document_type\": \"\",\n  \"first_name\": \"\",\n  \"gender\": \"\",\n  \"id\": 0,\n  \"language\": \"\",\n  \"last_name\": \"\",\n  \"legal_guardian_alias\": {},\n  \"legal_name\": \"\",\n  \"middle_name\": \"\",\n  \"nationality\": \"\",\n  \"notification_filters\": [\n    {\n      \"category\": \"\",\n      \"notification_delivery_method\": \"\",\n      \"notification_target\": \"\"\n    }\n  ],\n  \"place_of_birth\": \"\",\n  \"public_nick_name\": \"\",\n  \"public_uuid\": \"\",\n  \"region\": \"\",\n  \"relations\": [\n    {\n      \"counter_label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"counter_user_id\": \"\",\n      \"counter_user_status\": \"\",\n      \"label_user\": {},\n      \"relationship\": \"\",\n      \"status\": \"\",\n      \"user_id\": \"\",\n      \"user_status\": \"\"\n    }\n  ],\n  \"session_timeout\": 0,\n  \"signup_track_type\": \"\",\n  \"status\": \"\",\n  \"sub_status\": \"\",\n  \"subscription_type\": \"\",\n  \"tax_resident\": [\n    {\n      \"country\": \"\",\n      \"status\": \"\",\n      \"tax_number\": \"\"\n    }\n  ],\n  \"updated\": \"\",\n  \"version_terms_of_service\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user-person/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"avatar\": {\n    \"anchor_uuid\": \"\",\n    \"image\": [\n      {\n        \"attachment_public_uuid\": \"\",\n        \"content_type\": \"\",\n        \"height\": 0,\n        \"width\": 0\n      }\n    ],\n    \"style\": \"\",\n    \"uuid\": \"\"\n  },\n  \"avatar_uuid\": \"\",\n  \"country_of_birth\": \"\",\n  \"created\": \"\",\n  \"daily_limit_without_confirmation_login\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"date_of_birth\": \"\",\n  \"display_name\": \"\",\n  \"document_back_attachment_id\": 0,\n  \"document_country_of_issuance\": \"\",\n  \"document_front_attachment_id\": 0,\n  \"document_number\": \"\",\n  \"document_type\": \"\",\n  \"first_name\": \"\",\n  \"gender\": \"\",\n  \"id\": 0,\n  \"language\": \"\",\n  \"last_name\": \"\",\n  \"legal_guardian_alias\": {},\n  \"legal_name\": \"\",\n  \"middle_name\": \"\",\n  \"nationality\": \"\",\n  \"notification_filters\": [\n    {\n      \"category\": \"\",\n      \"notification_delivery_method\": \"\",\n      \"notification_target\": \"\"\n    }\n  ],\n  \"place_of_birth\": \"\",\n  \"public_nick_name\": \"\",\n  \"public_uuid\": \"\",\n  \"region\": \"\",\n  \"relations\": [\n    {\n      \"counter_label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"counter_user_id\": \"\",\n      \"counter_user_status\": \"\",\n      \"label_user\": {},\n      \"relationship\": \"\",\n      \"status\": \"\",\n      \"user_id\": \"\",\n      \"user_status\": \"\"\n    }\n  ],\n  \"session_timeout\": 0,\n  \"signup_track_type\": \"\",\n  \"status\": \"\",\n  \"sub_status\": \"\",\n  \"subscription_type\": \"\",\n  \"tax_resident\": [\n    {\n      \"country\": \"\",\n      \"status\": \"\",\n      \"tax_number\": \"\"\n    }\n  ],\n  \"updated\": \"\",\n  \"version_terms_of_service\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"avatar\": {\n    \"anchor_uuid\": \"\",\n    \"image\": [\n      {\n        \"attachment_public_uuid\": \"\",\n        \"content_type\": \"\",\n        \"height\": 0,\n        \"width\": 0\n      }\n    ],\n    \"style\": \"\",\n    \"uuid\": \"\"\n  },\n  \"avatar_uuid\": \"\",\n  \"country_of_birth\": \"\",\n  \"created\": \"\",\n  \"daily_limit_without_confirmation_login\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"date_of_birth\": \"\",\n  \"display_name\": \"\",\n  \"document_back_attachment_id\": 0,\n  \"document_country_of_issuance\": \"\",\n  \"document_front_attachment_id\": 0,\n  \"document_number\": \"\",\n  \"document_type\": \"\",\n  \"first_name\": \"\",\n  \"gender\": \"\",\n  \"id\": 0,\n  \"language\": \"\",\n  \"last_name\": \"\",\n  \"legal_guardian_alias\": {},\n  \"legal_name\": \"\",\n  \"middle_name\": \"\",\n  \"nationality\": \"\",\n  \"notification_filters\": [\n    {\n      \"category\": \"\",\n      \"notification_delivery_method\": \"\",\n      \"notification_target\": \"\"\n    }\n  ],\n  \"place_of_birth\": \"\",\n  \"public_nick_name\": \"\",\n  \"public_uuid\": \"\",\n  \"region\": \"\",\n  \"relations\": [\n    {\n      \"counter_label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"counter_user_id\": \"\",\n      \"counter_user_status\": \"\",\n      \"label_user\": {},\n      \"relationship\": \"\",\n      \"status\": \"\",\n      \"user_id\": \"\",\n      \"user_status\": \"\"\n    }\n  ],\n  \"session_timeout\": 0,\n  \"signup_track_type\": \"\",\n  \"status\": \"\",\n  \"sub_status\": \"\",\n  \"subscription_type\": \"\",\n  \"tax_resident\": [\n    {\n      \"country\": \"\",\n      \"status\": \"\",\n      \"tax_number\": \"\"\n    }\n  ],\n  \"updated\": \"\",\n  \"version_terms_of_service\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user-person/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user-person/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"avatar\": {\n    \"anchor_uuid\": \"\",\n    \"image\": [\n      {\n        \"attachment_public_uuid\": \"\",\n        \"content_type\": \"\",\n        \"height\": 0,\n        \"width\": 0\n      }\n    ],\n    \"style\": \"\",\n    \"uuid\": \"\"\n  },\n  \"avatar_uuid\": \"\",\n  \"country_of_birth\": \"\",\n  \"created\": \"\",\n  \"daily_limit_without_confirmation_login\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"date_of_birth\": \"\",\n  \"display_name\": \"\",\n  \"document_back_attachment_id\": 0,\n  \"document_country_of_issuance\": \"\",\n  \"document_front_attachment_id\": 0,\n  \"document_number\": \"\",\n  \"document_type\": \"\",\n  \"first_name\": \"\",\n  \"gender\": \"\",\n  \"id\": 0,\n  \"language\": \"\",\n  \"last_name\": \"\",\n  \"legal_guardian_alias\": {},\n  \"legal_name\": \"\",\n  \"middle_name\": \"\",\n  \"nationality\": \"\",\n  \"notification_filters\": [\n    {\n      \"category\": \"\",\n      \"notification_delivery_method\": \"\",\n      \"notification_target\": \"\"\n    }\n  ],\n  \"place_of_birth\": \"\",\n  \"public_nick_name\": \"\",\n  \"public_uuid\": \"\",\n  \"region\": \"\",\n  \"relations\": [\n    {\n      \"counter_label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"counter_user_id\": \"\",\n      \"counter_user_status\": \"\",\n      \"label_user\": {},\n      \"relationship\": \"\",\n      \"status\": \"\",\n      \"user_id\": \"\",\n      \"user_status\": \"\"\n    }\n  ],\n  \"session_timeout\": 0,\n  \"signup_track_type\": \"\",\n  \"status\": \"\",\n  \"sub_status\": \"\",\n  \"subscription_type\": \"\",\n  \"tax_resident\": [\n    {\n      \"country\": \"\",\n      \"status\": \"\",\n      \"tax_number\": \"\"\n    }\n  ],\n  \"updated\": \"\",\n  \"version_terms_of_service\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  address_main: {
    city: '',
    country: '',
    extra: '',
    house_number: '',
    is_user_address_updated: false,
    mailbox_name: '',
    po_box: '',
    postal_code: '',
    province: '',
    street: ''
  },
  address_postal: {},
  alias: [
    {
      name: '',
      service: '',
      type: '',
      value: ''
    }
  ],
  avatar: {
    anchor_uuid: '',
    image: [
      {
        attachment_public_uuid: '',
        content_type: '',
        height: 0,
        width: 0
      }
    ],
    style: '',
    uuid: ''
  },
  avatar_uuid: '',
  country_of_birth: '',
  created: '',
  daily_limit_without_confirmation_login: {
    currency: '',
    value: ''
  },
  date_of_birth: '',
  display_name: '',
  document_back_attachment_id: 0,
  document_country_of_issuance: '',
  document_front_attachment_id: 0,
  document_number: '',
  document_type: '',
  first_name: '',
  gender: '',
  id: 0,
  language: '',
  last_name: '',
  legal_guardian_alias: {},
  legal_name: '',
  middle_name: '',
  nationality: '',
  notification_filters: [
    {
      category: '',
      notification_delivery_method: '',
      notification_target: ''
    }
  ],
  place_of_birth: '',
  public_nick_name: '',
  public_uuid: '',
  region: '',
  relations: [
    {
      counter_label_user: {
        avatar: {},
        country: '',
        display_name: '',
        public_nick_name: '',
        uuid: ''
      },
      counter_user_id: '',
      counter_user_status: '',
      label_user: {},
      relationship: '',
      status: '',
      user_id: '',
      user_status: ''
    }
  ],
  session_timeout: 0,
  signup_track_type: '',
  status: '',
  sub_status: '',
  subscription_type: '',
  tax_resident: [
    {
      country: '',
      status: '',
      tax_number: ''
    }
  ],
  updated: '',
  version_terms_of_service: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user-person/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user-person/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    address_main: {
      city: '',
      country: '',
      extra: '',
      house_number: '',
      is_user_address_updated: false,
      mailbox_name: '',
      po_box: '',
      postal_code: '',
      province: '',
      street: ''
    },
    address_postal: {},
    alias: [{name: '', service: '', type: '', value: ''}],
    avatar: {
      anchor_uuid: '',
      image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
      style: '',
      uuid: ''
    },
    avatar_uuid: '',
    country_of_birth: '',
    created: '',
    daily_limit_without_confirmation_login: {currency: '', value: ''},
    date_of_birth: '',
    display_name: '',
    document_back_attachment_id: 0,
    document_country_of_issuance: '',
    document_front_attachment_id: 0,
    document_number: '',
    document_type: '',
    first_name: '',
    gender: '',
    id: 0,
    language: '',
    last_name: '',
    legal_guardian_alias: {},
    legal_name: '',
    middle_name: '',
    nationality: '',
    notification_filters: [{category: '', notification_delivery_method: '', notification_target: ''}],
    place_of_birth: '',
    public_nick_name: '',
    public_uuid: '',
    region: '',
    relations: [
      {
        counter_label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
        counter_user_id: '',
        counter_user_status: '',
        label_user: {},
        relationship: '',
        status: '',
        user_id: '',
        user_status: ''
      }
    ],
    session_timeout: 0,
    signup_track_type: '',
    status: '',
    sub_status: '',
    subscription_type: '',
    tax_resident: [{country: '', status: '', tax_number: ''}],
    updated: '',
    version_terms_of_service: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user-person/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"address_main":{"city":"","country":"","extra":"","house_number":"","is_user_address_updated":false,"mailbox_name":"","po_box":"","postal_code":"","province":"","street":""},"address_postal":{},"alias":[{"name":"","service":"","type":"","value":""}],"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"avatar_uuid":"","country_of_birth":"","created":"","daily_limit_without_confirmation_login":{"currency":"","value":""},"date_of_birth":"","display_name":"","document_back_attachment_id":0,"document_country_of_issuance":"","document_front_attachment_id":0,"document_number":"","document_type":"","first_name":"","gender":"","id":0,"language":"","last_name":"","legal_guardian_alias":{},"legal_name":"","middle_name":"","nationality":"","notification_filters":[{"category":"","notification_delivery_method":"","notification_target":""}],"place_of_birth":"","public_nick_name":"","public_uuid":"","region":"","relations":[{"counter_label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"counter_user_id":"","counter_user_status":"","label_user":{},"relationship":"","status":"","user_id":"","user_status":""}],"session_timeout":0,"signup_track_type":"","status":"","sub_status":"","subscription_type":"","tax_resident":[{"country":"","status":"","tax_number":""}],"updated":"","version_terms_of_service":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user-person/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "address_main": {\n    "city": "",\n    "country": "",\n    "extra": "",\n    "house_number": "",\n    "is_user_address_updated": false,\n    "mailbox_name": "",\n    "po_box": "",\n    "postal_code": "",\n    "province": "",\n    "street": ""\n  },\n  "address_postal": {},\n  "alias": [\n    {\n      "name": "",\n      "service": "",\n      "type": "",\n      "value": ""\n    }\n  ],\n  "avatar": {\n    "anchor_uuid": "",\n    "image": [\n      {\n        "attachment_public_uuid": "",\n        "content_type": "",\n        "height": 0,\n        "width": 0\n      }\n    ],\n    "style": "",\n    "uuid": ""\n  },\n  "avatar_uuid": "",\n  "country_of_birth": "",\n  "created": "",\n  "daily_limit_without_confirmation_login": {\n    "currency": "",\n    "value": ""\n  },\n  "date_of_birth": "",\n  "display_name": "",\n  "document_back_attachment_id": 0,\n  "document_country_of_issuance": "",\n  "document_front_attachment_id": 0,\n  "document_number": "",\n  "document_type": "",\n  "first_name": "",\n  "gender": "",\n  "id": 0,\n  "language": "",\n  "last_name": "",\n  "legal_guardian_alias": {},\n  "legal_name": "",\n  "middle_name": "",\n  "nationality": "",\n  "notification_filters": [\n    {\n      "category": "",\n      "notification_delivery_method": "",\n      "notification_target": ""\n    }\n  ],\n  "place_of_birth": "",\n  "public_nick_name": "",\n  "public_uuid": "",\n  "region": "",\n  "relations": [\n    {\n      "counter_label_user": {\n        "avatar": {},\n        "country": "",\n        "display_name": "",\n        "public_nick_name": "",\n        "uuid": ""\n      },\n      "counter_user_id": "",\n      "counter_user_status": "",\n      "label_user": {},\n      "relationship": "",\n      "status": "",\n      "user_id": "",\n      "user_status": ""\n    }\n  ],\n  "session_timeout": 0,\n  "signup_track_type": "",\n  "status": "",\n  "sub_status": "",\n  "subscription_type": "",\n  "tax_resident": [\n    {\n      "country": "",\n      "status": "",\n      "tax_number": ""\n    }\n  ],\n  "updated": "",\n  "version_terms_of_service": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"avatar\": {\n    \"anchor_uuid\": \"\",\n    \"image\": [\n      {\n        \"attachment_public_uuid\": \"\",\n        \"content_type\": \"\",\n        \"height\": 0,\n        \"width\": 0\n      }\n    ],\n    \"style\": \"\",\n    \"uuid\": \"\"\n  },\n  \"avatar_uuid\": \"\",\n  \"country_of_birth\": \"\",\n  \"created\": \"\",\n  \"daily_limit_without_confirmation_login\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"date_of_birth\": \"\",\n  \"display_name\": \"\",\n  \"document_back_attachment_id\": 0,\n  \"document_country_of_issuance\": \"\",\n  \"document_front_attachment_id\": 0,\n  \"document_number\": \"\",\n  \"document_type\": \"\",\n  \"first_name\": \"\",\n  \"gender\": \"\",\n  \"id\": 0,\n  \"language\": \"\",\n  \"last_name\": \"\",\n  \"legal_guardian_alias\": {},\n  \"legal_name\": \"\",\n  \"middle_name\": \"\",\n  \"nationality\": \"\",\n  \"notification_filters\": [\n    {\n      \"category\": \"\",\n      \"notification_delivery_method\": \"\",\n      \"notification_target\": \"\"\n    }\n  ],\n  \"place_of_birth\": \"\",\n  \"public_nick_name\": \"\",\n  \"public_uuid\": \"\",\n  \"region\": \"\",\n  \"relations\": [\n    {\n      \"counter_label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"counter_user_id\": \"\",\n      \"counter_user_status\": \"\",\n      \"label_user\": {},\n      \"relationship\": \"\",\n      \"status\": \"\",\n      \"user_id\": \"\",\n      \"user_status\": \"\"\n    }\n  ],\n  \"session_timeout\": 0,\n  \"signup_track_type\": \"\",\n  \"status\": \"\",\n  \"sub_status\": \"\",\n  \"subscription_type\": \"\",\n  \"tax_resident\": [\n    {\n      \"country\": \"\",\n      \"status\": \"\",\n      \"tax_number\": \"\"\n    }\n  ],\n  \"updated\": \"\",\n  \"version_terms_of_service\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user-person/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user-person/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  address_main: {
    city: '',
    country: '',
    extra: '',
    house_number: '',
    is_user_address_updated: false,
    mailbox_name: '',
    po_box: '',
    postal_code: '',
    province: '',
    street: ''
  },
  address_postal: {},
  alias: [{name: '', service: '', type: '', value: ''}],
  avatar: {
    anchor_uuid: '',
    image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
    style: '',
    uuid: ''
  },
  avatar_uuid: '',
  country_of_birth: '',
  created: '',
  daily_limit_without_confirmation_login: {currency: '', value: ''},
  date_of_birth: '',
  display_name: '',
  document_back_attachment_id: 0,
  document_country_of_issuance: '',
  document_front_attachment_id: 0,
  document_number: '',
  document_type: '',
  first_name: '',
  gender: '',
  id: 0,
  language: '',
  last_name: '',
  legal_guardian_alias: {},
  legal_name: '',
  middle_name: '',
  nationality: '',
  notification_filters: [{category: '', notification_delivery_method: '', notification_target: ''}],
  place_of_birth: '',
  public_nick_name: '',
  public_uuid: '',
  region: '',
  relations: [
    {
      counter_label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
      counter_user_id: '',
      counter_user_status: '',
      label_user: {},
      relationship: '',
      status: '',
      user_id: '',
      user_status: ''
    }
  ],
  session_timeout: 0,
  signup_track_type: '',
  status: '',
  sub_status: '',
  subscription_type: '',
  tax_resident: [{country: '', status: '', tax_number: ''}],
  updated: '',
  version_terms_of_service: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user-person/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    address_main: {
      city: '',
      country: '',
      extra: '',
      house_number: '',
      is_user_address_updated: false,
      mailbox_name: '',
      po_box: '',
      postal_code: '',
      province: '',
      street: ''
    },
    address_postal: {},
    alias: [{name: '', service: '', type: '', value: ''}],
    avatar: {
      anchor_uuid: '',
      image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
      style: '',
      uuid: ''
    },
    avatar_uuid: '',
    country_of_birth: '',
    created: '',
    daily_limit_without_confirmation_login: {currency: '', value: ''},
    date_of_birth: '',
    display_name: '',
    document_back_attachment_id: 0,
    document_country_of_issuance: '',
    document_front_attachment_id: 0,
    document_number: '',
    document_type: '',
    first_name: '',
    gender: '',
    id: 0,
    language: '',
    last_name: '',
    legal_guardian_alias: {},
    legal_name: '',
    middle_name: '',
    nationality: '',
    notification_filters: [{category: '', notification_delivery_method: '', notification_target: ''}],
    place_of_birth: '',
    public_nick_name: '',
    public_uuid: '',
    region: '',
    relations: [
      {
        counter_label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
        counter_user_id: '',
        counter_user_status: '',
        label_user: {},
        relationship: '',
        status: '',
        user_id: '',
        user_status: ''
      }
    ],
    session_timeout: 0,
    signup_track_type: '',
    status: '',
    sub_status: '',
    subscription_type: '',
    tax_resident: [{country: '', status: '', tax_number: ''}],
    updated: '',
    version_terms_of_service: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user-person/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  address_main: {
    city: '',
    country: '',
    extra: '',
    house_number: '',
    is_user_address_updated: false,
    mailbox_name: '',
    po_box: '',
    postal_code: '',
    province: '',
    street: ''
  },
  address_postal: {},
  alias: [
    {
      name: '',
      service: '',
      type: '',
      value: ''
    }
  ],
  avatar: {
    anchor_uuid: '',
    image: [
      {
        attachment_public_uuid: '',
        content_type: '',
        height: 0,
        width: 0
      }
    ],
    style: '',
    uuid: ''
  },
  avatar_uuid: '',
  country_of_birth: '',
  created: '',
  daily_limit_without_confirmation_login: {
    currency: '',
    value: ''
  },
  date_of_birth: '',
  display_name: '',
  document_back_attachment_id: 0,
  document_country_of_issuance: '',
  document_front_attachment_id: 0,
  document_number: '',
  document_type: '',
  first_name: '',
  gender: '',
  id: 0,
  language: '',
  last_name: '',
  legal_guardian_alias: {},
  legal_name: '',
  middle_name: '',
  nationality: '',
  notification_filters: [
    {
      category: '',
      notification_delivery_method: '',
      notification_target: ''
    }
  ],
  place_of_birth: '',
  public_nick_name: '',
  public_uuid: '',
  region: '',
  relations: [
    {
      counter_label_user: {
        avatar: {},
        country: '',
        display_name: '',
        public_nick_name: '',
        uuid: ''
      },
      counter_user_id: '',
      counter_user_status: '',
      label_user: {},
      relationship: '',
      status: '',
      user_id: '',
      user_status: ''
    }
  ],
  session_timeout: 0,
  signup_track_type: '',
  status: '',
  sub_status: '',
  subscription_type: '',
  tax_resident: [
    {
      country: '',
      status: '',
      tax_number: ''
    }
  ],
  updated: '',
  version_terms_of_service: ''
});

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}}/user-person/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    address_main: {
      city: '',
      country: '',
      extra: '',
      house_number: '',
      is_user_address_updated: false,
      mailbox_name: '',
      po_box: '',
      postal_code: '',
      province: '',
      street: ''
    },
    address_postal: {},
    alias: [{name: '', service: '', type: '', value: ''}],
    avatar: {
      anchor_uuid: '',
      image: [{attachment_public_uuid: '', content_type: '', height: 0, width: 0}],
      style: '',
      uuid: ''
    },
    avatar_uuid: '',
    country_of_birth: '',
    created: '',
    daily_limit_without_confirmation_login: {currency: '', value: ''},
    date_of_birth: '',
    display_name: '',
    document_back_attachment_id: 0,
    document_country_of_issuance: '',
    document_front_attachment_id: 0,
    document_number: '',
    document_type: '',
    first_name: '',
    gender: '',
    id: 0,
    language: '',
    last_name: '',
    legal_guardian_alias: {},
    legal_name: '',
    middle_name: '',
    nationality: '',
    notification_filters: [{category: '', notification_delivery_method: '', notification_target: ''}],
    place_of_birth: '',
    public_nick_name: '',
    public_uuid: '',
    region: '',
    relations: [
      {
        counter_label_user: {avatar: {}, country: '', display_name: '', public_nick_name: '', uuid: ''},
        counter_user_id: '',
        counter_user_status: '',
        label_user: {},
        relationship: '',
        status: '',
        user_id: '',
        user_status: ''
      }
    ],
    session_timeout: 0,
    signup_track_type: '',
    status: '',
    sub_status: '',
    subscription_type: '',
    tax_resident: [{country: '', status: '', tax_number: ''}],
    updated: '',
    version_terms_of_service: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user-person/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"address_main":{"city":"","country":"","extra":"","house_number":"","is_user_address_updated":false,"mailbox_name":"","po_box":"","postal_code":"","province":"","street":""},"address_postal":{},"alias":[{"name":"","service":"","type":"","value":""}],"avatar":{"anchor_uuid":"","image":[{"attachment_public_uuid":"","content_type":"","height":0,"width":0}],"style":"","uuid":""},"avatar_uuid":"","country_of_birth":"","created":"","daily_limit_without_confirmation_login":{"currency":"","value":""},"date_of_birth":"","display_name":"","document_back_attachment_id":0,"document_country_of_issuance":"","document_front_attachment_id":0,"document_number":"","document_type":"","first_name":"","gender":"","id":0,"language":"","last_name":"","legal_guardian_alias":{},"legal_name":"","middle_name":"","nationality":"","notification_filters":[{"category":"","notification_delivery_method":"","notification_target":""}],"place_of_birth":"","public_nick_name":"","public_uuid":"","region":"","relations":[{"counter_label_user":{"avatar":{},"country":"","display_name":"","public_nick_name":"","uuid":""},"counter_user_id":"","counter_user_status":"","label_user":{},"relationship":"","status":"","user_id":"","user_status":""}],"session_timeout":0,"signup_track_type":"","status":"","sub_status":"","subscription_type":"","tax_resident":[{"country":"","status":"","tax_number":""}],"updated":"","version_terms_of_service":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"address_main": @{ @"city": @"", @"country": @"", @"extra": @"", @"house_number": @"", @"is_user_address_updated": @NO, @"mailbox_name": @"", @"po_box": @"", @"postal_code": @"", @"province": @"", @"street": @"" },
                              @"address_postal": @{  },
                              @"alias": @[ @{ @"name": @"", @"service": @"", @"type": @"", @"value": @"" } ],
                              @"avatar": @{ @"anchor_uuid": @"", @"image": @[ @{ @"attachment_public_uuid": @"", @"content_type": @"", @"height": @0, @"width": @0 } ], @"style": @"", @"uuid": @"" },
                              @"avatar_uuid": @"",
                              @"country_of_birth": @"",
                              @"created": @"",
                              @"daily_limit_without_confirmation_login": @{ @"currency": @"", @"value": @"" },
                              @"date_of_birth": @"",
                              @"display_name": @"",
                              @"document_back_attachment_id": @0,
                              @"document_country_of_issuance": @"",
                              @"document_front_attachment_id": @0,
                              @"document_number": @"",
                              @"document_type": @"",
                              @"first_name": @"",
                              @"gender": @"",
                              @"id": @0,
                              @"language": @"",
                              @"last_name": @"",
                              @"legal_guardian_alias": @{  },
                              @"legal_name": @"",
                              @"middle_name": @"",
                              @"nationality": @"",
                              @"notification_filters": @[ @{ @"category": @"", @"notification_delivery_method": @"", @"notification_target": @"" } ],
                              @"place_of_birth": @"",
                              @"public_nick_name": @"",
                              @"public_uuid": @"",
                              @"region": @"",
                              @"relations": @[ @{ @"counter_label_user": @{ @"avatar": @{  }, @"country": @"", @"display_name": @"", @"public_nick_name": @"", @"uuid": @"" }, @"counter_user_id": @"", @"counter_user_status": @"", @"label_user": @{  }, @"relationship": @"", @"status": @"", @"user_id": @"", @"user_status": @"" } ],
                              @"session_timeout": @0,
                              @"signup_track_type": @"",
                              @"status": @"",
                              @"sub_status": @"",
                              @"subscription_type": @"",
                              @"tax_resident": @[ @{ @"country": @"", @"status": @"", @"tax_number": @"" } ],
                              @"updated": @"",
                              @"version_terms_of_service": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user-person/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user-person/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"avatar\": {\n    \"anchor_uuid\": \"\",\n    \"image\": [\n      {\n        \"attachment_public_uuid\": \"\",\n        \"content_type\": \"\",\n        \"height\": 0,\n        \"width\": 0\n      }\n    ],\n    \"style\": \"\",\n    \"uuid\": \"\"\n  },\n  \"avatar_uuid\": \"\",\n  \"country_of_birth\": \"\",\n  \"created\": \"\",\n  \"daily_limit_without_confirmation_login\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"date_of_birth\": \"\",\n  \"display_name\": \"\",\n  \"document_back_attachment_id\": 0,\n  \"document_country_of_issuance\": \"\",\n  \"document_front_attachment_id\": 0,\n  \"document_number\": \"\",\n  \"document_type\": \"\",\n  \"first_name\": \"\",\n  \"gender\": \"\",\n  \"id\": 0,\n  \"language\": \"\",\n  \"last_name\": \"\",\n  \"legal_guardian_alias\": {},\n  \"legal_name\": \"\",\n  \"middle_name\": \"\",\n  \"nationality\": \"\",\n  \"notification_filters\": [\n    {\n      \"category\": \"\",\n      \"notification_delivery_method\": \"\",\n      \"notification_target\": \"\"\n    }\n  ],\n  \"place_of_birth\": \"\",\n  \"public_nick_name\": \"\",\n  \"public_uuid\": \"\",\n  \"region\": \"\",\n  \"relations\": [\n    {\n      \"counter_label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"counter_user_id\": \"\",\n      \"counter_user_status\": \"\",\n      \"label_user\": {},\n      \"relationship\": \"\",\n      \"status\": \"\",\n      \"user_id\": \"\",\n      \"user_status\": \"\"\n    }\n  ],\n  \"session_timeout\": 0,\n  \"signup_track_type\": \"\",\n  \"status\": \"\",\n  \"sub_status\": \"\",\n  \"subscription_type\": \"\",\n  \"tax_resident\": [\n    {\n      \"country\": \"\",\n      \"status\": \"\",\n      \"tax_number\": \"\"\n    }\n  ],\n  \"updated\": \"\",\n  \"version_terms_of_service\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user-person/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'address_main' => [
        'city' => '',
        'country' => '',
        'extra' => '',
        'house_number' => '',
        'is_user_address_updated' => null,
        'mailbox_name' => '',
        'po_box' => '',
        'postal_code' => '',
        'province' => '',
        'street' => ''
    ],
    'address_postal' => [
        
    ],
    'alias' => [
        [
                'name' => '',
                'service' => '',
                'type' => '',
                'value' => ''
        ]
    ],
    'avatar' => [
        'anchor_uuid' => '',
        'image' => [
                [
                                'attachment_public_uuid' => '',
                                'content_type' => '',
                                'height' => 0,
                                'width' => 0
                ]
        ],
        'style' => '',
        'uuid' => ''
    ],
    'avatar_uuid' => '',
    'country_of_birth' => '',
    'created' => '',
    'daily_limit_without_confirmation_login' => [
        'currency' => '',
        'value' => ''
    ],
    'date_of_birth' => '',
    'display_name' => '',
    'document_back_attachment_id' => 0,
    'document_country_of_issuance' => '',
    'document_front_attachment_id' => 0,
    'document_number' => '',
    'document_type' => '',
    'first_name' => '',
    'gender' => '',
    'id' => 0,
    'language' => '',
    'last_name' => '',
    'legal_guardian_alias' => [
        
    ],
    'legal_name' => '',
    'middle_name' => '',
    'nationality' => '',
    'notification_filters' => [
        [
                'category' => '',
                'notification_delivery_method' => '',
                'notification_target' => ''
        ]
    ],
    'place_of_birth' => '',
    'public_nick_name' => '',
    'public_uuid' => '',
    'region' => '',
    'relations' => [
        [
                'counter_label_user' => [
                                'avatar' => [
                                                                
                                ],
                                'country' => '',
                                'display_name' => '',
                                'public_nick_name' => '',
                                'uuid' => ''
                ],
                'counter_user_id' => '',
                'counter_user_status' => '',
                'label_user' => [
                                
                ],
                'relationship' => '',
                'status' => '',
                'user_id' => '',
                'user_status' => ''
        ]
    ],
    'session_timeout' => 0,
    'signup_track_type' => '',
    'status' => '',
    'sub_status' => '',
    'subscription_type' => '',
    'tax_resident' => [
        [
                'country' => '',
                'status' => '',
                'tax_number' => ''
        ]
    ],
    'updated' => '',
    'version_terms_of_service' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user-person/:itemId', [
  'body' => '{
  "address_main": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_postal": {},
  "alias": [
    {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    }
  ],
  "avatar": {
    "anchor_uuid": "",
    "image": [
      {
        "attachment_public_uuid": "",
        "content_type": "",
        "height": 0,
        "width": 0
      }
    ],
    "style": "",
    "uuid": ""
  },
  "avatar_uuid": "",
  "country_of_birth": "",
  "created": "",
  "daily_limit_without_confirmation_login": {
    "currency": "",
    "value": ""
  },
  "date_of_birth": "",
  "display_name": "",
  "document_back_attachment_id": 0,
  "document_country_of_issuance": "",
  "document_front_attachment_id": 0,
  "document_number": "",
  "document_type": "",
  "first_name": "",
  "gender": "",
  "id": 0,
  "language": "",
  "last_name": "",
  "legal_guardian_alias": {},
  "legal_name": "",
  "middle_name": "",
  "nationality": "",
  "notification_filters": [
    {
      "category": "",
      "notification_delivery_method": "",
      "notification_target": ""
    }
  ],
  "place_of_birth": "",
  "public_nick_name": "",
  "public_uuid": "",
  "region": "",
  "relations": [
    {
      "counter_label_user": {
        "avatar": {},
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "counter_user_id": "",
      "counter_user_status": "",
      "label_user": {},
      "relationship": "",
      "status": "",
      "user_id": "",
      "user_status": ""
    }
  ],
  "session_timeout": 0,
  "signup_track_type": "",
  "status": "",
  "sub_status": "",
  "subscription_type": "",
  "tax_resident": [
    {
      "country": "",
      "status": "",
      "tax_number": ""
    }
  ],
  "updated": "",
  "version_terms_of_service": ""
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user-person/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'address_main' => [
    'city' => '',
    'country' => '',
    'extra' => '',
    'house_number' => '',
    'is_user_address_updated' => null,
    'mailbox_name' => '',
    'po_box' => '',
    'postal_code' => '',
    'province' => '',
    'street' => ''
  ],
  'address_postal' => [
    
  ],
  'alias' => [
    [
        'name' => '',
        'service' => '',
        'type' => '',
        'value' => ''
    ]
  ],
  'avatar' => [
    'anchor_uuid' => '',
    'image' => [
        [
                'attachment_public_uuid' => '',
                'content_type' => '',
                'height' => 0,
                'width' => 0
        ]
    ],
    'style' => '',
    'uuid' => ''
  ],
  'avatar_uuid' => '',
  'country_of_birth' => '',
  'created' => '',
  'daily_limit_without_confirmation_login' => [
    'currency' => '',
    'value' => ''
  ],
  'date_of_birth' => '',
  'display_name' => '',
  'document_back_attachment_id' => 0,
  'document_country_of_issuance' => '',
  'document_front_attachment_id' => 0,
  'document_number' => '',
  'document_type' => '',
  'first_name' => '',
  'gender' => '',
  'id' => 0,
  'language' => '',
  'last_name' => '',
  'legal_guardian_alias' => [
    
  ],
  'legal_name' => '',
  'middle_name' => '',
  'nationality' => '',
  'notification_filters' => [
    [
        'category' => '',
        'notification_delivery_method' => '',
        'notification_target' => ''
    ]
  ],
  'place_of_birth' => '',
  'public_nick_name' => '',
  'public_uuid' => '',
  'region' => '',
  'relations' => [
    [
        'counter_label_user' => [
                'avatar' => [
                                
                ],
                'country' => '',
                'display_name' => '',
                'public_nick_name' => '',
                'uuid' => ''
        ],
        'counter_user_id' => '',
        'counter_user_status' => '',
        'label_user' => [
                
        ],
        'relationship' => '',
        'status' => '',
        'user_id' => '',
        'user_status' => ''
    ]
  ],
  'session_timeout' => 0,
  'signup_track_type' => '',
  'status' => '',
  'sub_status' => '',
  'subscription_type' => '',
  'tax_resident' => [
    [
        'country' => '',
        'status' => '',
        'tax_number' => ''
    ]
  ],
  'updated' => '',
  'version_terms_of_service' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'address_main' => [
    'city' => '',
    'country' => '',
    'extra' => '',
    'house_number' => '',
    'is_user_address_updated' => null,
    'mailbox_name' => '',
    'po_box' => '',
    'postal_code' => '',
    'province' => '',
    'street' => ''
  ],
  'address_postal' => [
    
  ],
  'alias' => [
    [
        'name' => '',
        'service' => '',
        'type' => '',
        'value' => ''
    ]
  ],
  'avatar' => [
    'anchor_uuid' => '',
    'image' => [
        [
                'attachment_public_uuid' => '',
                'content_type' => '',
                'height' => 0,
                'width' => 0
        ]
    ],
    'style' => '',
    'uuid' => ''
  ],
  'avatar_uuid' => '',
  'country_of_birth' => '',
  'created' => '',
  'daily_limit_without_confirmation_login' => [
    'currency' => '',
    'value' => ''
  ],
  'date_of_birth' => '',
  'display_name' => '',
  'document_back_attachment_id' => 0,
  'document_country_of_issuance' => '',
  'document_front_attachment_id' => 0,
  'document_number' => '',
  'document_type' => '',
  'first_name' => '',
  'gender' => '',
  'id' => 0,
  'language' => '',
  'last_name' => '',
  'legal_guardian_alias' => [
    
  ],
  'legal_name' => '',
  'middle_name' => '',
  'nationality' => '',
  'notification_filters' => [
    [
        'category' => '',
        'notification_delivery_method' => '',
        'notification_target' => ''
    ]
  ],
  'place_of_birth' => '',
  'public_nick_name' => '',
  'public_uuid' => '',
  'region' => '',
  'relations' => [
    [
        'counter_label_user' => [
                'avatar' => [
                                
                ],
                'country' => '',
                'display_name' => '',
                'public_nick_name' => '',
                'uuid' => ''
        ],
        'counter_user_id' => '',
        'counter_user_status' => '',
        'label_user' => [
                
        ],
        'relationship' => '',
        'status' => '',
        'user_id' => '',
        'user_status' => ''
    ]
  ],
  'session_timeout' => 0,
  'signup_track_type' => '',
  'status' => '',
  'sub_status' => '',
  'subscription_type' => '',
  'tax_resident' => [
    [
        'country' => '',
        'status' => '',
        'tax_number' => ''
    ]
  ],
  'updated' => '',
  'version_terms_of_service' => ''
]));
$request->setRequestUrl('{{baseUrl}}/user-person/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user-person/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "address_main": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_postal": {},
  "alias": [
    {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    }
  ],
  "avatar": {
    "anchor_uuid": "",
    "image": [
      {
        "attachment_public_uuid": "",
        "content_type": "",
        "height": 0,
        "width": 0
      }
    ],
    "style": "",
    "uuid": ""
  },
  "avatar_uuid": "",
  "country_of_birth": "",
  "created": "",
  "daily_limit_without_confirmation_login": {
    "currency": "",
    "value": ""
  },
  "date_of_birth": "",
  "display_name": "",
  "document_back_attachment_id": 0,
  "document_country_of_issuance": "",
  "document_front_attachment_id": 0,
  "document_number": "",
  "document_type": "",
  "first_name": "",
  "gender": "",
  "id": 0,
  "language": "",
  "last_name": "",
  "legal_guardian_alias": {},
  "legal_name": "",
  "middle_name": "",
  "nationality": "",
  "notification_filters": [
    {
      "category": "",
      "notification_delivery_method": "",
      "notification_target": ""
    }
  ],
  "place_of_birth": "",
  "public_nick_name": "",
  "public_uuid": "",
  "region": "",
  "relations": [
    {
      "counter_label_user": {
        "avatar": {},
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "counter_user_id": "",
      "counter_user_status": "",
      "label_user": {},
      "relationship": "",
      "status": "",
      "user_id": "",
      "user_status": ""
    }
  ],
  "session_timeout": 0,
  "signup_track_type": "",
  "status": "",
  "sub_status": "",
  "subscription_type": "",
  "tax_resident": [
    {
      "country": "",
      "status": "",
      "tax_number": ""
    }
  ],
  "updated": "",
  "version_terms_of_service": ""
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user-person/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "address_main": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_postal": {},
  "alias": [
    {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    }
  ],
  "avatar": {
    "anchor_uuid": "",
    "image": [
      {
        "attachment_public_uuid": "",
        "content_type": "",
        "height": 0,
        "width": 0
      }
    ],
    "style": "",
    "uuid": ""
  },
  "avatar_uuid": "",
  "country_of_birth": "",
  "created": "",
  "daily_limit_without_confirmation_login": {
    "currency": "",
    "value": ""
  },
  "date_of_birth": "",
  "display_name": "",
  "document_back_attachment_id": 0,
  "document_country_of_issuance": "",
  "document_front_attachment_id": 0,
  "document_number": "",
  "document_type": "",
  "first_name": "",
  "gender": "",
  "id": 0,
  "language": "",
  "last_name": "",
  "legal_guardian_alias": {},
  "legal_name": "",
  "middle_name": "",
  "nationality": "",
  "notification_filters": [
    {
      "category": "",
      "notification_delivery_method": "",
      "notification_target": ""
    }
  ],
  "place_of_birth": "",
  "public_nick_name": "",
  "public_uuid": "",
  "region": "",
  "relations": [
    {
      "counter_label_user": {
        "avatar": {},
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "counter_user_id": "",
      "counter_user_status": "",
      "label_user": {},
      "relationship": "",
      "status": "",
      "user_id": "",
      "user_status": ""
    }
  ],
  "session_timeout": 0,
  "signup_track_type": "",
  "status": "",
  "sub_status": "",
  "subscription_type": "",
  "tax_resident": [
    {
      "country": "",
      "status": "",
      "tax_number": ""
    }
  ],
  "updated": "",
  "version_terms_of_service": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"avatar\": {\n    \"anchor_uuid\": \"\",\n    \"image\": [\n      {\n        \"attachment_public_uuid\": \"\",\n        \"content_type\": \"\",\n        \"height\": 0,\n        \"width\": 0\n      }\n    ],\n    \"style\": \"\",\n    \"uuid\": \"\"\n  },\n  \"avatar_uuid\": \"\",\n  \"country_of_birth\": \"\",\n  \"created\": \"\",\n  \"daily_limit_without_confirmation_login\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"date_of_birth\": \"\",\n  \"display_name\": \"\",\n  \"document_back_attachment_id\": 0,\n  \"document_country_of_issuance\": \"\",\n  \"document_front_attachment_id\": 0,\n  \"document_number\": \"\",\n  \"document_type\": \"\",\n  \"first_name\": \"\",\n  \"gender\": \"\",\n  \"id\": 0,\n  \"language\": \"\",\n  \"last_name\": \"\",\n  \"legal_guardian_alias\": {},\n  \"legal_name\": \"\",\n  \"middle_name\": \"\",\n  \"nationality\": \"\",\n  \"notification_filters\": [\n    {\n      \"category\": \"\",\n      \"notification_delivery_method\": \"\",\n      \"notification_target\": \"\"\n    }\n  ],\n  \"place_of_birth\": \"\",\n  \"public_nick_name\": \"\",\n  \"public_uuid\": \"\",\n  \"region\": \"\",\n  \"relations\": [\n    {\n      \"counter_label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"counter_user_id\": \"\",\n      \"counter_user_status\": \"\",\n      \"label_user\": {},\n      \"relationship\": \"\",\n      \"status\": \"\",\n      \"user_id\": \"\",\n      \"user_status\": \"\"\n    }\n  ],\n  \"session_timeout\": 0,\n  \"signup_track_type\": \"\",\n  \"status\": \"\",\n  \"sub_status\": \"\",\n  \"subscription_type\": \"\",\n  \"tax_resident\": [\n    {\n      \"country\": \"\",\n      \"status\": \"\",\n      \"tax_number\": \"\"\n    }\n  ],\n  \"updated\": \"\",\n  \"version_terms_of_service\": \"\"\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user-person/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user-person/:itemId"

payload = {
    "address_main": {
        "city": "",
        "country": "",
        "extra": "",
        "house_number": "",
        "is_user_address_updated": False,
        "mailbox_name": "",
        "po_box": "",
        "postal_code": "",
        "province": "",
        "street": ""
    },
    "address_postal": {},
    "alias": [
        {
            "name": "",
            "service": "",
            "type": "",
            "value": ""
        }
    ],
    "avatar": {
        "anchor_uuid": "",
        "image": [
            {
                "attachment_public_uuid": "",
                "content_type": "",
                "height": 0,
                "width": 0
            }
        ],
        "style": "",
        "uuid": ""
    },
    "avatar_uuid": "",
    "country_of_birth": "",
    "created": "",
    "daily_limit_without_confirmation_login": {
        "currency": "",
        "value": ""
    },
    "date_of_birth": "",
    "display_name": "",
    "document_back_attachment_id": 0,
    "document_country_of_issuance": "",
    "document_front_attachment_id": 0,
    "document_number": "",
    "document_type": "",
    "first_name": "",
    "gender": "",
    "id": 0,
    "language": "",
    "last_name": "",
    "legal_guardian_alias": {},
    "legal_name": "",
    "middle_name": "",
    "nationality": "",
    "notification_filters": [
        {
            "category": "",
            "notification_delivery_method": "",
            "notification_target": ""
        }
    ],
    "place_of_birth": "",
    "public_nick_name": "",
    "public_uuid": "",
    "region": "",
    "relations": [
        {
            "counter_label_user": {
                "avatar": {},
                "country": "",
                "display_name": "",
                "public_nick_name": "",
                "uuid": ""
            },
            "counter_user_id": "",
            "counter_user_status": "",
            "label_user": {},
            "relationship": "",
            "status": "",
            "user_id": "",
            "user_status": ""
        }
    ],
    "session_timeout": 0,
    "signup_track_type": "",
    "status": "",
    "sub_status": "",
    "subscription_type": "",
    "tax_resident": [
        {
            "country": "",
            "status": "",
            "tax_number": ""
        }
    ],
    "updated": "",
    "version_terms_of_service": ""
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user-person/:itemId"

payload <- "{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"avatar\": {\n    \"anchor_uuid\": \"\",\n    \"image\": [\n      {\n        \"attachment_public_uuid\": \"\",\n        \"content_type\": \"\",\n        \"height\": 0,\n        \"width\": 0\n      }\n    ],\n    \"style\": \"\",\n    \"uuid\": \"\"\n  },\n  \"avatar_uuid\": \"\",\n  \"country_of_birth\": \"\",\n  \"created\": \"\",\n  \"daily_limit_without_confirmation_login\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"date_of_birth\": \"\",\n  \"display_name\": \"\",\n  \"document_back_attachment_id\": 0,\n  \"document_country_of_issuance\": \"\",\n  \"document_front_attachment_id\": 0,\n  \"document_number\": \"\",\n  \"document_type\": \"\",\n  \"first_name\": \"\",\n  \"gender\": \"\",\n  \"id\": 0,\n  \"language\": \"\",\n  \"last_name\": \"\",\n  \"legal_guardian_alias\": {},\n  \"legal_name\": \"\",\n  \"middle_name\": \"\",\n  \"nationality\": \"\",\n  \"notification_filters\": [\n    {\n      \"category\": \"\",\n      \"notification_delivery_method\": \"\",\n      \"notification_target\": \"\"\n    }\n  ],\n  \"place_of_birth\": \"\",\n  \"public_nick_name\": \"\",\n  \"public_uuid\": \"\",\n  \"region\": \"\",\n  \"relations\": [\n    {\n      \"counter_label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"counter_user_id\": \"\",\n      \"counter_user_status\": \"\",\n      \"label_user\": {},\n      \"relationship\": \"\",\n      \"status\": \"\",\n      \"user_id\": \"\",\n      \"user_status\": \"\"\n    }\n  ],\n  \"session_timeout\": 0,\n  \"signup_track_type\": \"\",\n  \"status\": \"\",\n  \"sub_status\": \"\",\n  \"subscription_type\": \"\",\n  \"tax_resident\": [\n    {\n      \"country\": \"\",\n      \"status\": \"\",\n      \"tax_number\": \"\"\n    }\n  ],\n  \"updated\": \"\",\n  \"version_terms_of_service\": \"\"\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user-person/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"avatar\": {\n    \"anchor_uuid\": \"\",\n    \"image\": [\n      {\n        \"attachment_public_uuid\": \"\",\n        \"content_type\": \"\",\n        \"height\": 0,\n        \"width\": 0\n      }\n    ],\n    \"style\": \"\",\n    \"uuid\": \"\"\n  },\n  \"avatar_uuid\": \"\",\n  \"country_of_birth\": \"\",\n  \"created\": \"\",\n  \"daily_limit_without_confirmation_login\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"date_of_birth\": \"\",\n  \"display_name\": \"\",\n  \"document_back_attachment_id\": 0,\n  \"document_country_of_issuance\": \"\",\n  \"document_front_attachment_id\": 0,\n  \"document_number\": \"\",\n  \"document_type\": \"\",\n  \"first_name\": \"\",\n  \"gender\": \"\",\n  \"id\": 0,\n  \"language\": \"\",\n  \"last_name\": \"\",\n  \"legal_guardian_alias\": {},\n  \"legal_name\": \"\",\n  \"middle_name\": \"\",\n  \"nationality\": \"\",\n  \"notification_filters\": [\n    {\n      \"category\": \"\",\n      \"notification_delivery_method\": \"\",\n      \"notification_target\": \"\"\n    }\n  ],\n  \"place_of_birth\": \"\",\n  \"public_nick_name\": \"\",\n  \"public_uuid\": \"\",\n  \"region\": \"\",\n  \"relations\": [\n    {\n      \"counter_label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"counter_user_id\": \"\",\n      \"counter_user_status\": \"\",\n      \"label_user\": {},\n      \"relationship\": \"\",\n      \"status\": \"\",\n      \"user_id\": \"\",\n      \"user_status\": \"\"\n    }\n  ],\n  \"session_timeout\": 0,\n  \"signup_track_type\": \"\",\n  \"status\": \"\",\n  \"sub_status\": \"\",\n  \"subscription_type\": \"\",\n  \"tax_resident\": [\n    {\n      \"country\": \"\",\n      \"status\": \"\",\n      \"tax_number\": \"\"\n    }\n  ],\n  \"updated\": \"\",\n  \"version_terms_of_service\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user-person/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"address_main\": {\n    \"city\": \"\",\n    \"country\": \"\",\n    \"extra\": \"\",\n    \"house_number\": \"\",\n    \"is_user_address_updated\": false,\n    \"mailbox_name\": \"\",\n    \"po_box\": \"\",\n    \"postal_code\": \"\",\n    \"province\": \"\",\n    \"street\": \"\"\n  },\n  \"address_postal\": {},\n  \"alias\": [\n    {\n      \"name\": \"\",\n      \"service\": \"\",\n      \"type\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"avatar\": {\n    \"anchor_uuid\": \"\",\n    \"image\": [\n      {\n        \"attachment_public_uuid\": \"\",\n        \"content_type\": \"\",\n        \"height\": 0,\n        \"width\": 0\n      }\n    ],\n    \"style\": \"\",\n    \"uuid\": \"\"\n  },\n  \"avatar_uuid\": \"\",\n  \"country_of_birth\": \"\",\n  \"created\": \"\",\n  \"daily_limit_without_confirmation_login\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"date_of_birth\": \"\",\n  \"display_name\": \"\",\n  \"document_back_attachment_id\": 0,\n  \"document_country_of_issuance\": \"\",\n  \"document_front_attachment_id\": 0,\n  \"document_number\": \"\",\n  \"document_type\": \"\",\n  \"first_name\": \"\",\n  \"gender\": \"\",\n  \"id\": 0,\n  \"language\": \"\",\n  \"last_name\": \"\",\n  \"legal_guardian_alias\": {},\n  \"legal_name\": \"\",\n  \"middle_name\": \"\",\n  \"nationality\": \"\",\n  \"notification_filters\": [\n    {\n      \"category\": \"\",\n      \"notification_delivery_method\": \"\",\n      \"notification_target\": \"\"\n    }\n  ],\n  \"place_of_birth\": \"\",\n  \"public_nick_name\": \"\",\n  \"public_uuid\": \"\",\n  \"region\": \"\",\n  \"relations\": [\n    {\n      \"counter_label_user\": {\n        \"avatar\": {},\n        \"country\": \"\",\n        \"display_name\": \"\",\n        \"public_nick_name\": \"\",\n        \"uuid\": \"\"\n      },\n      \"counter_user_id\": \"\",\n      \"counter_user_status\": \"\",\n      \"label_user\": {},\n      \"relationship\": \"\",\n      \"status\": \"\",\n      \"user_id\": \"\",\n      \"user_status\": \"\"\n    }\n  ],\n  \"session_timeout\": 0,\n  \"signup_track_type\": \"\",\n  \"status\": \"\",\n  \"sub_status\": \"\",\n  \"subscription_type\": \"\",\n  \"tax_resident\": [\n    {\n      \"country\": \"\",\n      \"status\": \"\",\n      \"tax_number\": \"\"\n    }\n  ],\n  \"updated\": \"\",\n  \"version_terms_of_service\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user-person/:itemId";

    let payload = json!({
        "address_main": json!({
            "city": "",
            "country": "",
            "extra": "",
            "house_number": "",
            "is_user_address_updated": false,
            "mailbox_name": "",
            "po_box": "",
            "postal_code": "",
            "province": "",
            "street": ""
        }),
        "address_postal": json!({}),
        "alias": (
            json!({
                "name": "",
                "service": "",
                "type": "",
                "value": ""
            })
        ),
        "avatar": json!({
            "anchor_uuid": "",
            "image": (
                json!({
                    "attachment_public_uuid": "",
                    "content_type": "",
                    "height": 0,
                    "width": 0
                })
            ),
            "style": "",
            "uuid": ""
        }),
        "avatar_uuid": "",
        "country_of_birth": "",
        "created": "",
        "daily_limit_without_confirmation_login": json!({
            "currency": "",
            "value": ""
        }),
        "date_of_birth": "",
        "display_name": "",
        "document_back_attachment_id": 0,
        "document_country_of_issuance": "",
        "document_front_attachment_id": 0,
        "document_number": "",
        "document_type": "",
        "first_name": "",
        "gender": "",
        "id": 0,
        "language": "",
        "last_name": "",
        "legal_guardian_alias": json!({}),
        "legal_name": "",
        "middle_name": "",
        "nationality": "",
        "notification_filters": (
            json!({
                "category": "",
                "notification_delivery_method": "",
                "notification_target": ""
            })
        ),
        "place_of_birth": "",
        "public_nick_name": "",
        "public_uuid": "",
        "region": "",
        "relations": (
            json!({
                "counter_label_user": json!({
                    "avatar": json!({}),
                    "country": "",
                    "display_name": "",
                    "public_nick_name": "",
                    "uuid": ""
                }),
                "counter_user_id": "",
                "counter_user_status": "",
                "label_user": json!({}),
                "relationship": "",
                "status": "",
                "user_id": "",
                "user_status": ""
            })
        ),
        "session_timeout": 0,
        "signup_track_type": "",
        "status": "",
        "sub_status": "",
        "subscription_type": "",
        "tax_resident": (
            json!({
                "country": "",
                "status": "",
                "tax_number": ""
            })
        ),
        "updated": "",
        "version_terms_of_service": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user-person/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "address_main": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_postal": {},
  "alias": [
    {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    }
  ],
  "avatar": {
    "anchor_uuid": "",
    "image": [
      {
        "attachment_public_uuid": "",
        "content_type": "",
        "height": 0,
        "width": 0
      }
    ],
    "style": "",
    "uuid": ""
  },
  "avatar_uuid": "",
  "country_of_birth": "",
  "created": "",
  "daily_limit_without_confirmation_login": {
    "currency": "",
    "value": ""
  },
  "date_of_birth": "",
  "display_name": "",
  "document_back_attachment_id": 0,
  "document_country_of_issuance": "",
  "document_front_attachment_id": 0,
  "document_number": "",
  "document_type": "",
  "first_name": "",
  "gender": "",
  "id": 0,
  "language": "",
  "last_name": "",
  "legal_guardian_alias": {},
  "legal_name": "",
  "middle_name": "",
  "nationality": "",
  "notification_filters": [
    {
      "category": "",
      "notification_delivery_method": "",
      "notification_target": ""
    }
  ],
  "place_of_birth": "",
  "public_nick_name": "",
  "public_uuid": "",
  "region": "",
  "relations": [
    {
      "counter_label_user": {
        "avatar": {},
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "counter_user_id": "",
      "counter_user_status": "",
      "label_user": {},
      "relationship": "",
      "status": "",
      "user_id": "",
      "user_status": ""
    }
  ],
  "session_timeout": 0,
  "signup_track_type": "",
  "status": "",
  "sub_status": "",
  "subscription_type": "",
  "tax_resident": [
    {
      "country": "",
      "status": "",
      "tax_number": ""
    }
  ],
  "updated": "",
  "version_terms_of_service": ""
}'
echo '{
  "address_main": {
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  },
  "address_postal": {},
  "alias": [
    {
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    }
  ],
  "avatar": {
    "anchor_uuid": "",
    "image": [
      {
        "attachment_public_uuid": "",
        "content_type": "",
        "height": 0,
        "width": 0
      }
    ],
    "style": "",
    "uuid": ""
  },
  "avatar_uuid": "",
  "country_of_birth": "",
  "created": "",
  "daily_limit_without_confirmation_login": {
    "currency": "",
    "value": ""
  },
  "date_of_birth": "",
  "display_name": "",
  "document_back_attachment_id": 0,
  "document_country_of_issuance": "",
  "document_front_attachment_id": 0,
  "document_number": "",
  "document_type": "",
  "first_name": "",
  "gender": "",
  "id": 0,
  "language": "",
  "last_name": "",
  "legal_guardian_alias": {},
  "legal_name": "",
  "middle_name": "",
  "nationality": "",
  "notification_filters": [
    {
      "category": "",
      "notification_delivery_method": "",
      "notification_target": ""
    }
  ],
  "place_of_birth": "",
  "public_nick_name": "",
  "public_uuid": "",
  "region": "",
  "relations": [
    {
      "counter_label_user": {
        "avatar": {},
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      },
      "counter_user_id": "",
      "counter_user_status": "",
      "label_user": {},
      "relationship": "",
      "status": "",
      "user_id": "",
      "user_status": ""
    }
  ],
  "session_timeout": 0,
  "signup_track_type": "",
  "status": "",
  "sub_status": "",
  "subscription_type": "",
  "tax_resident": [
    {
      "country": "",
      "status": "",
      "tax_number": ""
    }
  ],
  "updated": "",
  "version_terms_of_service": ""
}' |  \
  http PUT {{baseUrl}}/user-person/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "address_main": {\n    "city": "",\n    "country": "",\n    "extra": "",\n    "house_number": "",\n    "is_user_address_updated": false,\n    "mailbox_name": "",\n    "po_box": "",\n    "postal_code": "",\n    "province": "",\n    "street": ""\n  },\n  "address_postal": {},\n  "alias": [\n    {\n      "name": "",\n      "service": "",\n      "type": "",\n      "value": ""\n    }\n  ],\n  "avatar": {\n    "anchor_uuid": "",\n    "image": [\n      {\n        "attachment_public_uuid": "",\n        "content_type": "",\n        "height": 0,\n        "width": 0\n      }\n    ],\n    "style": "",\n    "uuid": ""\n  },\n  "avatar_uuid": "",\n  "country_of_birth": "",\n  "created": "",\n  "daily_limit_without_confirmation_login": {\n    "currency": "",\n    "value": ""\n  },\n  "date_of_birth": "",\n  "display_name": "",\n  "document_back_attachment_id": 0,\n  "document_country_of_issuance": "",\n  "document_front_attachment_id": 0,\n  "document_number": "",\n  "document_type": "",\n  "first_name": "",\n  "gender": "",\n  "id": 0,\n  "language": "",\n  "last_name": "",\n  "legal_guardian_alias": {},\n  "legal_name": "",\n  "middle_name": "",\n  "nationality": "",\n  "notification_filters": [\n    {\n      "category": "",\n      "notification_delivery_method": "",\n      "notification_target": ""\n    }\n  ],\n  "place_of_birth": "",\n  "public_nick_name": "",\n  "public_uuid": "",\n  "region": "",\n  "relations": [\n    {\n      "counter_label_user": {\n        "avatar": {},\n        "country": "",\n        "display_name": "",\n        "public_nick_name": "",\n        "uuid": ""\n      },\n      "counter_user_id": "",\n      "counter_user_status": "",\n      "label_user": {},\n      "relationship": "",\n      "status": "",\n      "user_id": "",\n      "user_status": ""\n    }\n  ],\n  "session_timeout": 0,\n  "signup_track_type": "",\n  "status": "",\n  "sub_status": "",\n  "subscription_type": "",\n  "tax_resident": [\n    {\n      "country": "",\n      "status": "",\n      "tax_number": ""\n    }\n  ],\n  "updated": "",\n  "version_terms_of_service": ""\n}' \
  --output-document \
  - {{baseUrl}}/user-person/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "address_main": [
    "city": "",
    "country": "",
    "extra": "",
    "house_number": "",
    "is_user_address_updated": false,
    "mailbox_name": "",
    "po_box": "",
    "postal_code": "",
    "province": "",
    "street": ""
  ],
  "address_postal": [],
  "alias": [
    [
      "name": "",
      "service": "",
      "type": "",
      "value": ""
    ]
  ],
  "avatar": [
    "anchor_uuid": "",
    "image": [
      [
        "attachment_public_uuid": "",
        "content_type": "",
        "height": 0,
        "width": 0
      ]
    ],
    "style": "",
    "uuid": ""
  ],
  "avatar_uuid": "",
  "country_of_birth": "",
  "created": "",
  "daily_limit_without_confirmation_login": [
    "currency": "",
    "value": ""
  ],
  "date_of_birth": "",
  "display_name": "",
  "document_back_attachment_id": 0,
  "document_country_of_issuance": "",
  "document_front_attachment_id": 0,
  "document_number": "",
  "document_type": "",
  "first_name": "",
  "gender": "",
  "id": 0,
  "language": "",
  "last_name": "",
  "legal_guardian_alias": [],
  "legal_name": "",
  "middle_name": "",
  "nationality": "",
  "notification_filters": [
    [
      "category": "",
      "notification_delivery_method": "",
      "notification_target": ""
    ]
  ],
  "place_of_birth": "",
  "public_nick_name": "",
  "public_uuid": "",
  "region": "",
  "relations": [
    [
      "counter_label_user": [
        "avatar": [],
        "country": "",
        "display_name": "",
        "public_nick_name": "",
        "uuid": ""
      ],
      "counter_user_id": "",
      "counter_user_status": "",
      "label_user": [],
      "relationship": "",
      "status": "",
      "user_id": "",
      "user_status": ""
    ]
  ],
  "session_timeout": 0,
  "signup_track_type": "",
  "status": "",
  "sub_status": "",
  "subscription_type": "",
  "tax_resident": [
    [
      "country": "",
      "status": "",
      "tax_number": ""
    ]
  ],
  "updated": "",
  "version_terms_of_service": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user-person/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_WhitelistSdd_for_User
{{baseUrl}}/user/:userID/whitelist-sdd
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/whitelist-sdd");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/whitelist-sdd" {:headers {:user-agent ""
                                                                                :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/whitelist-sdd"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/whitelist-sdd"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/whitelist-sdd");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/whitelist-sdd"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/whitelist-sdd HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/whitelist-sdd")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/whitelist-sdd"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/whitelist-sdd")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/whitelist-sdd")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/whitelist-sdd');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/whitelist-sdd',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/whitelist-sdd';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/whitelist-sdd',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/whitelist-sdd")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/whitelist-sdd',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/whitelist-sdd',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/whitelist-sdd');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/whitelist-sdd',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/whitelist-sdd';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/whitelist-sdd"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/whitelist-sdd" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/whitelist-sdd",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/whitelist-sdd', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/whitelist-sdd');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/whitelist-sdd');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/whitelist-sdd' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/whitelist-sdd' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/whitelist-sdd", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/whitelist-sdd"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/whitelist-sdd"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/whitelist-sdd")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/whitelist-sdd') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/whitelist-sdd";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/whitelist-sdd \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/whitelist-sdd \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/whitelist-sdd
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/whitelist-sdd")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_WhitelistSdd_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd" {:headers {:user-agent ""
                                                                                                                     :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_WhitelistSdd_for_User
{{baseUrl}}/user/:userID/whitelist-sdd/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/whitelist-sdd/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/whitelist-sdd/:itemId" {:headers {:user-agent ""
                                                                                        :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/whitelist-sdd/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/whitelist-sdd/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/whitelist-sdd/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/whitelist-sdd/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/whitelist-sdd/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/whitelist-sdd/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/whitelist-sdd/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/whitelist-sdd/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/whitelist-sdd/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/whitelist-sdd/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/whitelist-sdd/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/whitelist-sdd/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/whitelist-sdd/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/whitelist-sdd/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/whitelist-sdd/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/whitelist-sdd/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/whitelist-sdd/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/whitelist-sdd/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/whitelist-sdd/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/whitelist-sdd/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/whitelist-sdd/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/whitelist-sdd/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/whitelist-sdd/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/whitelist-sdd/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/whitelist-sdd/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/whitelist-sdd/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/whitelist-sdd/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/whitelist-sdd/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/whitelist-sdd/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/whitelist-sdd/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/whitelist-sdd/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/whitelist-sdd/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/whitelist-sdd/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/whitelist-sdd/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/whitelist-sdd/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/whitelist-sdd/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/whitelist-sdd/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_WhitelistSdd_for_User_MonetaryAccount
{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
monetary-accountID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd/:itemId" {:headers {:user-agent ""
                                                                                                                             :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/monetary-account/:monetary-accountID/whitelist-sdd/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_WhitelistSddOneOff_for_User
{{baseUrl}}/user/:userID/whitelist-sdd-one-off
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
BODY json

{
  "maximum_amount_per_month": {
    "currency": "",
    "value": ""
  },
  "monetary_account_paying_id": 0,
  "request_id": 0
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/whitelist-sdd-one-off");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/whitelist-sdd-one-off" {:headers {:user-agent ""
                                                                                         :x-bunq-client-authentication ""}
                                                                               :content-type :json
                                                                               :form-params {:maximum_amount_per_month {:currency ""
                                                                                                                        :value ""}
                                                                                             :monetary_account_paying_id 0
                                                                                             :request_id 0}})
require "http/client"

url = "{{baseUrl}}/user/:userID/whitelist-sdd-one-off"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/whitelist-sdd-one-off"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/whitelist-sdd-one-off");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/whitelist-sdd-one-off"

	payload := strings.NewReader("{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/whitelist-sdd-one-off HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 129

{
  "maximum_amount_per_month": {
    "currency": "",
    "value": ""
  },
  "monetary_account_paying_id": 0,
  "request_id": 0
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/whitelist-sdd-one-off")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/whitelist-sdd-one-off"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/whitelist-sdd-one-off")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/whitelist-sdd-one-off")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}")
  .asString();
const data = JSON.stringify({
  maximum_amount_per_month: {
    currency: '',
    value: ''
  },
  monetary_account_paying_id: 0,
  request_id: 0
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/whitelist-sdd-one-off');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/whitelist-sdd-one-off',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    maximum_amount_per_month: {currency: '', value: ''},
    monetary_account_paying_id: 0,
    request_id: 0
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/whitelist-sdd-one-off';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"maximum_amount_per_month":{"currency":"","value":""},"monetary_account_paying_id":0,"request_id":0}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/whitelist-sdd-one-off',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "maximum_amount_per_month": {\n    "currency": "",\n    "value": ""\n  },\n  "monetary_account_paying_id": 0,\n  "request_id": 0\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/whitelist-sdd-one-off")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/whitelist-sdd-one-off',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  maximum_amount_per_month: {currency: '', value: ''},
  monetary_account_paying_id: 0,
  request_id: 0
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/whitelist-sdd-one-off',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    maximum_amount_per_month: {currency: '', value: ''},
    monetary_account_paying_id: 0,
    request_id: 0
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/whitelist-sdd-one-off');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  maximum_amount_per_month: {
    currency: '',
    value: ''
  },
  monetary_account_paying_id: 0,
  request_id: 0
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/whitelist-sdd-one-off',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    maximum_amount_per_month: {currency: '', value: ''},
    monetary_account_paying_id: 0,
    request_id: 0
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/whitelist-sdd-one-off';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"maximum_amount_per_month":{"currency":"","value":""},"monetary_account_paying_id":0,"request_id":0}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"maximum_amount_per_month": @{ @"currency": @"", @"value": @"" },
                              @"monetary_account_paying_id": @0,
                              @"request_id": @0 };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/whitelist-sdd-one-off"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/whitelist-sdd-one-off" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/whitelist-sdd-one-off",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'maximum_amount_per_month' => [
        'currency' => '',
        'value' => ''
    ],
    'monetary_account_paying_id' => 0,
    'request_id' => 0
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/whitelist-sdd-one-off', [
  'body' => '{
  "maximum_amount_per_month": {
    "currency": "",
    "value": ""
  },
  "monetary_account_paying_id": 0,
  "request_id": 0
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/whitelist-sdd-one-off');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'maximum_amount_per_month' => [
    'currency' => '',
    'value' => ''
  ],
  'monetary_account_paying_id' => 0,
  'request_id' => 0
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'maximum_amount_per_month' => [
    'currency' => '',
    'value' => ''
  ],
  'monetary_account_paying_id' => 0,
  'request_id' => 0
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/whitelist-sdd-one-off');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/whitelist-sdd-one-off' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "maximum_amount_per_month": {
    "currency": "",
    "value": ""
  },
  "monetary_account_paying_id": 0,
  "request_id": 0
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/whitelist-sdd-one-off' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "maximum_amount_per_month": {
    "currency": "",
    "value": ""
  },
  "monetary_account_paying_id": 0,
  "request_id": 0
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/whitelist-sdd-one-off", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/whitelist-sdd-one-off"

payload = {
    "maximum_amount_per_month": {
        "currency": "",
        "value": ""
    },
    "monetary_account_paying_id": 0,
    "request_id": 0
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/whitelist-sdd-one-off"

payload <- "{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/whitelist-sdd-one-off")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/whitelist-sdd-one-off') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/whitelist-sdd-one-off";

    let payload = json!({
        "maximum_amount_per_month": json!({
            "currency": "",
            "value": ""
        }),
        "monetary_account_paying_id": 0,
        "request_id": 0
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/whitelist-sdd-one-off \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "maximum_amount_per_month": {
    "currency": "",
    "value": ""
  },
  "monetary_account_paying_id": 0,
  "request_id": 0
}'
echo '{
  "maximum_amount_per_month": {
    "currency": "",
    "value": ""
  },
  "monetary_account_paying_id": 0,
  "request_id": 0
}' |  \
  http POST {{baseUrl}}/user/:userID/whitelist-sdd-one-off \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "maximum_amount_per_month": {\n    "currency": "",\n    "value": ""\n  },\n  "monetary_account_paying_id": 0,\n  "request_id": 0\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/whitelist-sdd-one-off
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "maximum_amount_per_month": [
    "currency": "",
    "value": ""
  ],
  "monetary_account_paying_id": 0,
  "request_id": 0
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/whitelist-sdd-one-off")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_WhitelistSddOneOff_for_User
{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId" {:headers {:user-agent ""
                                                                                                   :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/whitelist-sdd-one-off/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/whitelist-sdd-one-off/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/whitelist-sdd-one-off/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/whitelist-sdd-one-off/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/whitelist-sdd-one-off/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/whitelist-sdd-one-off/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/whitelist-sdd-one-off/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId"]
                                                       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}}/user/:userID/whitelist-sdd-one-off/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/whitelist-sdd-one-off/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/whitelist-sdd-one-off/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_WhitelistSddOneOff_for_User
{{baseUrl}}/user/:userID/whitelist-sdd-one-off
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/whitelist-sdd-one-off");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/whitelist-sdd-one-off" {:headers {:user-agent ""
                                                                                        :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/whitelist-sdd-one-off"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/whitelist-sdd-one-off"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/whitelist-sdd-one-off");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/whitelist-sdd-one-off"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/whitelist-sdd-one-off HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/whitelist-sdd-one-off")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/whitelist-sdd-one-off"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/whitelist-sdd-one-off")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/whitelist-sdd-one-off")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/whitelist-sdd-one-off');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/whitelist-sdd-one-off',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/whitelist-sdd-one-off';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/whitelist-sdd-one-off',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/whitelist-sdd-one-off")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/whitelist-sdd-one-off',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/whitelist-sdd-one-off',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/whitelist-sdd-one-off');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/whitelist-sdd-one-off',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/whitelist-sdd-one-off';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/whitelist-sdd-one-off"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/whitelist-sdd-one-off" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/whitelist-sdd-one-off",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/whitelist-sdd-one-off', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/whitelist-sdd-one-off');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/whitelist-sdd-one-off');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/whitelist-sdd-one-off' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/whitelist-sdd-one-off' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/whitelist-sdd-one-off", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/whitelist-sdd-one-off"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/whitelist-sdd-one-off"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/whitelist-sdd-one-off")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/whitelist-sdd-one-off') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/whitelist-sdd-one-off";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/whitelist-sdd-one-off \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/whitelist-sdd-one-off \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/whitelist-sdd-one-off
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/whitelist-sdd-one-off")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_WhitelistSddOneOff_for_User
{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId" {:headers {:user-agent ""
                                                                                                :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/whitelist-sdd-one-off/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/whitelist-sdd-one-off/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/whitelist-sdd-one-off/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/whitelist-sdd-one-off/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_WhitelistSddOneOff_for_User
{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
BODY json

{
  "maximum_amount_per_month": {
    "currency": "",
    "value": ""
  },
  "monetary_account_paying_id": 0,
  "request_id": 0
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId" {:headers {:user-agent ""
                                                                                                :x-bunq-client-authentication ""}
                                                                                      :content-type :json
                                                                                      :form-params {:maximum_amount_per_month {:currency ""
                                                                                                                               :value ""}
                                                                                                    :monetary_account_paying_id 0
                                                                                                    :request_id 0}})
require "http/client"

url = "{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId"

	payload := strings.NewReader("{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/whitelist-sdd-one-off/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 129

{
  "maximum_amount_per_month": {
    "currency": "",
    "value": ""
  },
  "monetary_account_paying_id": 0,
  "request_id": 0
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}")
  .asString();
const data = JSON.stringify({
  maximum_amount_per_month: {
    currency: '',
    value: ''
  },
  monetary_account_paying_id: 0,
  request_id: 0
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    maximum_amount_per_month: {currency: '', value: ''},
    monetary_account_paying_id: 0,
    request_id: 0
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"maximum_amount_per_month":{"currency":"","value":""},"monetary_account_paying_id":0,"request_id":0}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "maximum_amount_per_month": {\n    "currency": "",\n    "value": ""\n  },\n  "monetary_account_paying_id": 0,\n  "request_id": 0\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/whitelist-sdd-one-off/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  maximum_amount_per_month: {currency: '', value: ''},
  monetary_account_paying_id: 0,
  request_id: 0
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    maximum_amount_per_month: {currency: '', value: ''},
    monetary_account_paying_id: 0,
    request_id: 0
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  maximum_amount_per_month: {
    currency: '',
    value: ''
  },
  monetary_account_paying_id: 0,
  request_id: 0
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    maximum_amount_per_month: {currency: '', value: ''},
    monetary_account_paying_id: 0,
    request_id: 0
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"maximum_amount_per_month":{"currency":"","value":""},"monetary_account_paying_id":0,"request_id":0}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"maximum_amount_per_month": @{ @"currency": @"", @"value": @"" },
                              @"monetary_account_paying_id": @0,
                              @"request_id": @0 };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'maximum_amount_per_month' => [
        'currency' => '',
        'value' => ''
    ],
    'monetary_account_paying_id' => 0,
    'request_id' => 0
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId', [
  'body' => '{
  "maximum_amount_per_month": {
    "currency": "",
    "value": ""
  },
  "monetary_account_paying_id": 0,
  "request_id": 0
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'maximum_amount_per_month' => [
    'currency' => '',
    'value' => ''
  ],
  'monetary_account_paying_id' => 0,
  'request_id' => 0
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'maximum_amount_per_month' => [
    'currency' => '',
    'value' => ''
  ],
  'monetary_account_paying_id' => 0,
  'request_id' => 0
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "maximum_amount_per_month": {
    "currency": "",
    "value": ""
  },
  "monetary_account_paying_id": 0,
  "request_id": 0
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "maximum_amount_per_month": {
    "currency": "",
    "value": ""
  },
  "monetary_account_paying_id": 0,
  "request_id": 0
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/whitelist-sdd-one-off/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId"

payload = {
    "maximum_amount_per_month": {
        "currency": "",
        "value": ""
    },
    "monetary_account_paying_id": 0,
    "request_id": 0
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId"

payload <- "{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/whitelist-sdd-one-off/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId";

    let payload = json!({
        "maximum_amount_per_month": json!({
            "currency": "",
            "value": ""
        }),
        "monetary_account_paying_id": 0,
        "request_id": 0
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "maximum_amount_per_month": {
    "currency": "",
    "value": ""
  },
  "monetary_account_paying_id": 0,
  "request_id": 0
}'
echo '{
  "maximum_amount_per_month": {
    "currency": "",
    "value": ""
  },
  "monetary_account_paying_id": 0,
  "request_id": 0
}' |  \
  http PUT {{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "maximum_amount_per_month": {\n    "currency": "",\n    "value": ""\n  },\n  "monetary_account_paying_id": 0,\n  "request_id": 0\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "maximum_amount_per_month": [
    "currency": "",
    "value": ""
  ],
  "monetary_account_paying_id": 0,
  "request_id": 0
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/whitelist-sdd-one-off/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST CREATE_WhitelistSddRecurring_for_User
{{baseUrl}}/user/:userID/whitelist-sdd-recurring
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
BODY json

{
  "maximum_amount_per_month": {
    "currency": "",
    "value": ""
  },
  "monetary_account_paying_id": 0,
  "request_id": 0
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/whitelist-sdd-recurring");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/user/:userID/whitelist-sdd-recurring" {:headers {:user-agent ""
                                                                                           :x-bunq-client-authentication ""}
                                                                                 :content-type :json
                                                                                 :form-params {:maximum_amount_per_month {:currency ""
                                                                                                                          :value ""}
                                                                                               :monetary_account_paying_id 0
                                                                                               :request_id 0}})
require "http/client"

url = "{{baseUrl}}/user/:userID/whitelist-sdd-recurring"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/whitelist-sdd-recurring"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/whitelist-sdd-recurring");
var request = new RestRequest("", Method.Post);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/whitelist-sdd-recurring"

	payload := strings.NewReader("{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/user/:userID/whitelist-sdd-recurring HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 129

{
  "maximum_amount_per_month": {
    "currency": "",
    "value": ""
  },
  "monetary_account_paying_id": 0,
  "request_id": 0
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/user/:userID/whitelist-sdd-recurring")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/whitelist-sdd-recurring"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/whitelist-sdd-recurring")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/user/:userID/whitelist-sdd-recurring")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}")
  .asString();
const data = JSON.stringify({
  maximum_amount_per_month: {
    currency: '',
    value: ''
  },
  monetary_account_paying_id: 0,
  request_id: 0
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/user/:userID/whitelist-sdd-recurring');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/whitelist-sdd-recurring',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    maximum_amount_per_month: {currency: '', value: ''},
    monetary_account_paying_id: 0,
    request_id: 0
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/whitelist-sdd-recurring';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"maximum_amount_per_month":{"currency":"","value":""},"monetary_account_paying_id":0,"request_id":0}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/whitelist-sdd-recurring',
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "maximum_amount_per_month": {\n    "currency": "",\n    "value": ""\n  },\n  "monetary_account_paying_id": 0,\n  "request_id": 0\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/whitelist-sdd-recurring")
  .post(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/whitelist-sdd-recurring',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  maximum_amount_per_month: {currency: '', value: ''},
  monetary_account_paying_id: 0,
  request_id: 0
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/whitelist-sdd-recurring',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    maximum_amount_per_month: {currency: '', value: ''},
    monetary_account_paying_id: 0,
    request_id: 0
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/user/:userID/whitelist-sdd-recurring');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  maximum_amount_per_month: {
    currency: '',
    value: ''
  },
  monetary_account_paying_id: 0,
  request_id: 0
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/user/:userID/whitelist-sdd-recurring',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    maximum_amount_per_month: {currency: '', value: ''},
    monetary_account_paying_id: 0,
    request_id: 0
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/whitelist-sdd-recurring';
const options = {
  method: 'POST',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"maximum_amount_per_month":{"currency":"","value":""},"monetary_account_paying_id":0,"request_id":0}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"maximum_amount_per_month": @{ @"currency": @"", @"value": @"" },
                              @"monetary_account_paying_id": @0,
                              @"request_id": @0 };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/whitelist-sdd-recurring"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/whitelist-sdd-recurring" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/whitelist-sdd-recurring",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'maximum_amount_per_month' => [
        'currency' => '',
        'value' => ''
    ],
    'monetary_account_paying_id' => 0,
    'request_id' => 0
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/user/:userID/whitelist-sdd-recurring', [
  'body' => '{
  "maximum_amount_per_month": {
    "currency": "",
    "value": ""
  },
  "monetary_account_paying_id": 0,
  "request_id": 0
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/whitelist-sdd-recurring');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'maximum_amount_per_month' => [
    'currency' => '',
    'value' => ''
  ],
  'monetary_account_paying_id' => 0,
  'request_id' => 0
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'maximum_amount_per_month' => [
    'currency' => '',
    'value' => ''
  ],
  'monetary_account_paying_id' => 0,
  'request_id' => 0
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/whitelist-sdd-recurring');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/whitelist-sdd-recurring' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "maximum_amount_per_month": {
    "currency": "",
    "value": ""
  },
  "monetary_account_paying_id": 0,
  "request_id": 0
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/whitelist-sdd-recurring' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "maximum_amount_per_month": {
    "currency": "",
    "value": ""
  },
  "monetary_account_paying_id": 0,
  "request_id": 0
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("POST", "/baseUrl/user/:userID/whitelist-sdd-recurring", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/whitelist-sdd-recurring"

payload = {
    "maximum_amount_per_month": {
        "currency": "",
        "value": ""
    },
    "monetary_account_paying_id": 0,
    "request_id": 0
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/whitelist-sdd-recurring"

payload <- "{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/whitelist-sdd-recurring")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/user/:userID/whitelist-sdd-recurring') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/whitelist-sdd-recurring";

    let payload = json!({
        "maximum_amount_per_month": json!({
            "currency": "",
            "value": ""
        }),
        "monetary_account_paying_id": 0,
        "request_id": 0
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/user/:userID/whitelist-sdd-recurring \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "maximum_amount_per_month": {
    "currency": "",
    "value": ""
  },
  "monetary_account_paying_id": 0,
  "request_id": 0
}'
echo '{
  "maximum_amount_per_month": {
    "currency": "",
    "value": ""
  },
  "monetary_account_paying_id": 0,
  "request_id": 0
}' |  \
  http POST {{baseUrl}}/user/:userID/whitelist-sdd-recurring \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method POST \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "maximum_amount_per_month": {\n    "currency": "",\n    "value": ""\n  },\n  "monetary_account_paying_id": 0,\n  "request_id": 0\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/whitelist-sdd-recurring
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "maximum_amount_per_month": [
    "currency": "",
    "value": ""
  ],
  "monetary_account_paying_id": 0,
  "request_id": 0
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/whitelist-sdd-recurring")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
DELETE DELETE_WhitelistSddRecurring_for_User
{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId" {:headers {:user-agent ""
                                                                                                     :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

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}}/user/:userID/whitelist-sdd-recurring/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId");
var request = new RestRequest("", Method.Delete);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId"

	req, _ := http.NewRequest("DELETE", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
DELETE /baseUrl/user/:userID/whitelist-sdd-recurring/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .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}}/user/:userID/whitelist-sdd-recurring/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const 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}}/user/:userID/whitelist-sdd-recurring/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId',
  method: 'DELETE',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId")
  .delete(null)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/whitelist-sdd-recurring/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/user/:userID/whitelist-sdd-recurring/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

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}}/user/:userID/whitelist-sdd-recurring/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId';
const options = {
  method: 'DELETE',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId"]
                                                       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}}/user/:userID/whitelist-sdd-recurring/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "DELETE",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('DELETE', '{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId');
$request->setMethod(HTTP_METH_DELETE);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId');
$request->setRequestMethod('DELETE');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId' -Method DELETE -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId' -Method DELETE -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("DELETE", "/baseUrl/user/:userID/whitelist-sdd-recurring/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.delete(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId"

response <- VERB("DELETE", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Delete.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.delete('/baseUrl/user/:userID/whitelist-sdd-recurring/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http DELETE {{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method DELETE \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET List_all_WhitelistSddRecurring_for_User
{{baseUrl}}/user/:userID/whitelist-sdd-recurring
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/whitelist-sdd-recurring");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/whitelist-sdd-recurring" {:headers {:user-agent ""
                                                                                          :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/whitelist-sdd-recurring"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/whitelist-sdd-recurring"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/whitelist-sdd-recurring");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/whitelist-sdd-recurring"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/whitelist-sdd-recurring HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/whitelist-sdd-recurring")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/whitelist-sdd-recurring"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/whitelist-sdd-recurring")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/whitelist-sdd-recurring")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/whitelist-sdd-recurring');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/whitelist-sdd-recurring',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/whitelist-sdd-recurring';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/whitelist-sdd-recurring',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/whitelist-sdd-recurring")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/whitelist-sdd-recurring',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/whitelist-sdd-recurring',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/whitelist-sdd-recurring');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/whitelist-sdd-recurring',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/whitelist-sdd-recurring';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/whitelist-sdd-recurring"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/whitelist-sdd-recurring" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/whitelist-sdd-recurring",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/whitelist-sdd-recurring', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/whitelist-sdd-recurring');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/whitelist-sdd-recurring');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/whitelist-sdd-recurring' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/whitelist-sdd-recurring' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/whitelist-sdd-recurring", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/whitelist-sdd-recurring"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/whitelist-sdd-recurring"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/whitelist-sdd-recurring")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/whitelist-sdd-recurring') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/whitelist-sdd-recurring";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/whitelist-sdd-recurring \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/whitelist-sdd-recurring \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/whitelist-sdd-recurring
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/whitelist-sdd-recurring")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET READ_WhitelistSddRecurring_for_User
{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId" {:headers {:user-agent ""
                                                                                                  :x-bunq-client-authentication ""}})
require "http/client"

url = "{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
}

response = HTTP::Client.get url, headers: headers
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId");
var request = new RestRequest("", Method.Get);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId"

	req, _ := http.NewRequest("GET", url, nil)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/user/:userID/whitelist-sdd-recurring/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId',
  method: 'GET',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId")
  .get()
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/whitelist-sdd-recurring/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': ''
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId',
  headers: {'user-agent': '', 'x-bunq-client-authentication': ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId';
const options = {method: 'GET', headers: {'user-agent': '', 'x-bunq-client-authentication': ''}};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"" };

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];
[request setAllHTTPHeaderFields:headers];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
] in

Client.call ~headers `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
  CURLOPT_HTTPHEADER => [
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId', [
  'headers' => [
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId');
$request->setMethod(HTTP_METH_GET);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId');
$request->setRequestMethod('GET');
$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => ''
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId' -Method GET -Headers $headers
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId' -Method GET -Headers $headers
import http.client

conn = http.client.HTTPSConnection("example.com")

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': ""
}

conn.request("GET", "/baseUrl/user/:userID/whitelist-sdd-recurring/:itemId", headers=headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId"

headers = {
    "user-agent": "",
    "x-bunq-client-authentication": ""
}

response = requests.get(url, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId"

response <- VERB("GET", url, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/user/:userID/whitelist-sdd-recurring/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId";

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.get(url)
        .headers(headers)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: '
http GET {{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method GET \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --output-document \
  - {{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": ""
]

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"
request.allHTTPHeaderFields = headers

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PUT UPDATE_WhitelistSddRecurring_for_User
{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId
HEADERS

User-Agent
X-Bunq-Client-Authentication
QUERY PARAMS

userID
itemId
BODY json

{
  "maximum_amount_per_month": {
    "currency": "",
    "value": ""
  },
  "monetary_account_paying_id": 0,
  "request_id": 0
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "user-agent: ");
headers = curl_slist_append(headers, "x-bunq-client-authentication: ");
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId" {:headers {:user-agent ""
                                                                                                  :x-bunq-client-authentication ""}
                                                                                        :content-type :json
                                                                                        :form-params {:maximum_amount_per_month {:currency ""
                                                                                                                                 :value ""}
                                                                                                      :monetary_account_paying_id 0
                                                                                                      :request_id 0}})
require "http/client"

url = "{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId"
headers = HTTP::Headers{
  "user-agent" => ""
  "x-bunq-client-authentication" => ""
  "content-type" => "application/json"
}
reqBody = "{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId"),
    Headers =
    {
        { "user-agent", "" },
        { "x-bunq-client-authentication", "" },
    },
    Content = new StringContent("{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId");
var request = new RestRequest("", Method.Put);
request.AddHeader("user-agent", "");
request.AddHeader("x-bunq-client-authentication", "");
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId"

	payload := strings.NewReader("{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("user-agent", "")
	req.Header.Add("x-bunq-client-authentication", "")
	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/user/:userID/whitelist-sdd-recurring/:itemId HTTP/1.1
User-Agent: 
X-Bunq-Client-Authentication: 
Content-Type: application/json
Host: example.com
Content-Length: 129

{
  "maximum_amount_per_month": {
    "currency": "",
    "value": ""
  },
  "monetary_account_paying_id": 0,
  "request_id": 0
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId")
  .setHeader("user-agent", "")
  .setHeader("x-bunq-client-authentication", "")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId"))
    .header("user-agent", "")
    .header("x-bunq-client-authentication", "")
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId")
  .header("user-agent", "")
  .header("x-bunq-client-authentication", "")
  .header("content-type", "application/json")
  .body("{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}")
  .asString();
const data = JSON.stringify({
  maximum_amount_per_month: {
    currency: '',
    value: ''
  },
  monetary_account_paying_id: 0,
  request_id: 0
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId');
xhr.setRequestHeader('user-agent', '');
xhr.setRequestHeader('x-bunq-client-authentication', '');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    maximum_amount_per_month: {currency: '', value: ''},
    monetary_account_paying_id: 0,
    request_id: 0
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"maximum_amount_per_month":{"currency":"","value":""},"monetary_account_paying_id":0,"request_id":0}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId',
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "maximum_amount_per_month": {\n    "currency": "",\n    "value": ""\n  },\n  "monetary_account_paying_id": 0,\n  "request_id": 0\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId")
  .put(body)
  .addHeader("user-agent", "")
  .addHeader("x-bunq-client-authentication", "")
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/user/:userID/whitelist-sdd-recurring/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  maximum_amount_per_month: {currency: '', value: ''},
  monetary_account_paying_id: 0,
  request_id: 0
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: {
    maximum_amount_per_month: {currency: '', value: ''},
    monetary_account_paying_id: 0,
    request_id: 0
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId');

req.headers({
  'user-agent': '',
  'x-bunq-client-authentication': '',
  'content-type': 'application/json'
});

req.type('json');
req.send({
  maximum_amount_per_month: {
    currency: '',
    value: ''
  },
  monetary_account_paying_id: 0,
  request_id: 0
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  data: {
    maximum_amount_per_month: {currency: '', value: ''},
    monetary_account_paying_id: 0,
    request_id: 0
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId';
const options = {
  method: 'PUT',
  headers: {
    'user-agent': '',
    'x-bunq-client-authentication': '',
    'content-type': 'application/json'
  },
  body: '{"maximum_amount_per_month":{"currency":"","value":""},"monetary_account_paying_id":0,"request_id":0}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"user-agent": @"",
                           @"x-bunq-client-authentication": @"",
                           @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"maximum_amount_per_month": @{ @"currency": @"", @"value": @"" },
                              @"monetary_account_paying_id": @0,
                              @"request_id": @0 };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId" in
let headers = Header.add_list (Header.init ()) [
  ("user-agent", "");
  ("x-bunq-client-authentication", "");
  ("content-type", "application/json");
] in
let body = Cohttp_lwt_body.of_string "{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'maximum_amount_per_month' => [
        'currency' => '',
        'value' => ''
    ],
    'monetary_account_paying_id' => 0,
    'request_id' => 0
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json",
    "user-agent: ",
    "x-bunq-client-authentication: "
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId', [
  'body' => '{
  "maximum_amount_per_month": {
    "currency": "",
    "value": ""
  },
  "monetary_account_paying_id": 0,
  "request_id": 0
}',
  'headers' => [
    'content-type' => 'application/json',
    'user-agent' => '',
    'x-bunq-client-authentication' => '',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'maximum_amount_per_month' => [
    'currency' => '',
    'value' => ''
  ],
  'monetary_account_paying_id' => 0,
  'request_id' => 0
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'maximum_amount_per_month' => [
    'currency' => '',
    'value' => ''
  ],
  'monetary_account_paying_id' => 0,
  'request_id' => 0
]));
$request->setRequestUrl('{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'user-agent' => '',
  'x-bunq-client-authentication' => '',
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "maximum_amount_per_month": {
    "currency": "",
    "value": ""
  },
  "monetary_account_paying_id": 0,
  "request_id": 0
}'
$headers=@{}
$headers.Add("user-agent", "")
$headers.Add("x-bunq-client-authentication", "")
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "maximum_amount_per_month": {
    "currency": "",
    "value": ""
  },
  "monetary_account_paying_id": 0,
  "request_id": 0
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}"

headers = {
    'user-agent': "",
    'x-bunq-client-authentication': "",
    'content-type': "application/json"
}

conn.request("PUT", "/baseUrl/user/:userID/whitelist-sdd-recurring/:itemId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId"

payload = {
    "maximum_amount_per_month": {
        "currency": "",
        "value": ""
    },
    "monetary_account_paying_id": 0,
    "request_id": 0
}
headers = {
    "user-agent": "",
    "x-bunq-client-authentication": "",
    "content-type": "application/json"
}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId"

payload <- "{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, add_headers('user-agent' = '', 'x-bunq-client-authentication' = ''), content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["user-agent"] = ''
request["x-bunq-client-authentication"] = ''
request["content-type"] = 'application/json'
request.body = "{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/user/:userID/whitelist-sdd-recurring/:itemId') do |req|
  req.headers['user-agent'] = ''
  req.headers['x-bunq-client-authentication'] = ''
  req.body = "{\n  \"maximum_amount_per_month\": {\n    \"currency\": \"\",\n    \"value\": \"\"\n  },\n  \"monetary_account_paying_id\": 0,\n  \"request_id\": 0\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId";

    let payload = json!({
        "maximum_amount_per_month": json!({
            "currency": "",
            "value": ""
        }),
        "monetary_account_paying_id": 0,
        "request_id": 0
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("user-agent", "".parse().unwrap());
    headers.insert("x-bunq-client-authentication", "".parse().unwrap());
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId \
  --header 'content-type: application/json' \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --data '{
  "maximum_amount_per_month": {
    "currency": "",
    "value": ""
  },
  "monetary_account_paying_id": 0,
  "request_id": 0
}'
echo '{
  "maximum_amount_per_month": {
    "currency": "",
    "value": ""
  },
  "monetary_account_paying_id": 0,
  "request_id": 0
}' |  \
  http PUT {{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId \
  content-type:application/json \
  user-agent:'' \
  x-bunq-client-authentication:''
wget --quiet \
  --method PUT \
  --header 'user-agent: ' \
  --header 'x-bunq-client-authentication: ' \
  --header 'content-type: application/json' \
  --body-data '{\n  "maximum_amount_per_month": {\n    "currency": "",\n    "value": ""\n  },\n  "monetary_account_paying_id": 0,\n  "request_id": 0\n}' \
  --output-document \
  - {{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId
import Foundation

let headers = [
  "user-agent": "",
  "x-bunq-client-authentication": "",
  "content-type": "application/json"
]
let parameters = [
  "maximum_amount_per_month": [
    "currency": "",
    "value": ""
  ],
  "monetary_account_paying_id": 0,
  "request_id": 0
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/user/:userID/whitelist-sdd-recurring/:itemId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()